A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 
All Classes All Packages

A

ABORT - com.linkedin.venice.hooks.StoreLifecycleEventOutcome
 
ABORT - com.linkedin.venice.hooks.StoreVersionLifecycleEventOutcome
Fail the push job associated with this hook.
ABORT_MIGRATION - com.linkedin.venice.Command
 
ABORT_MIGRATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
ABORT_MIGRATION - com.linkedin.venice.controllerapi.ControllerRoute
 
abortMigration(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
abortMigration(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
This command should be sent to src controller, not dest controller
abortMigration(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
abortMigration(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Abort store migration by resetting migration flag at the source cluster, resetting storeConfig, and updating "cluster" in "/storeConfigs" znode back to the source cluster.
abortMigration(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Abort store migration by sending a ABORT_MIGRATION admin message.
abortMigration(String, String, String, String, boolean, boolean[]) - Static method in class com.linkedin.venice.AdminTool
 
AbortMigration - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
AbortMigration() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
Default constructor.
AbortMigration(CharSequence, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
All-args constructor.
AbstractAsyncFuture<T> - Class in com.linkedin.alpini.base.concurrency.impl
Created by acurtis on 5/1/18.
AbstractAsyncFuture() - Constructor for class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
AbstractAvroChunkingAdapter<T> - Class in com.linkedin.davinci.storage.chunking
Read compute and write compute chunking adapter
AbstractAvroChunkingAdapter() - Constructor for class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
AbstractAvroComputeRequestBuilder<K> - Class in com.linkedin.venice.client.store
This abstract class contains all the common field and APIs for compute request builder; for each new compute request version, there will be a new builder class that extends this class and the new builder will include customized fields and APIs.
AbstractAvroComputeRequestBuilder(AvroGenericReadComputeStoreClient, Schema) - Constructor for class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
AbstractAvroRecordReader<INPUT_KEY,​INPUT_VALUE> - Class in com.linkedin.venice.hadoop.input.recordreader.avro
An abstraction for a record reader that reads records from input into Avro-serialized keys and values.
AbstractAvroRecordReader(Schema, String, String, ETLValueSchemaTransformation, Schema) - Constructor for class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
This constructor is used when data is read from HDFS.
AbstractAvroStoreClient<K,​V> - Class in com.linkedin.venice.client.store
 
AbstractAvroStoreClient(TransportClient, boolean, ClientConfig) - Constructor for class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
AbstractClientRoutingStrategy - Class in com.linkedin.venice.fastclient.meta
 
AbstractClientRoutingStrategy() - Constructor for class com.linkedin.venice.fastclient.meta.AbstractClientRoutingStrategy
 
AbstractCoalescingBufferQueue10294 - Class in io.netty.channel
Forked from Netty's AbstractCoalescingBufferQueue (4.1.42) Includes fix to guard readableBytes from re-entry.
AbstractCoalescingBufferQueue10294(Channel, int) - Constructor for class io.netty.channel.AbstractCoalescingBufferQueue10294
Create a new instance.
AbstractDataWriterSparkJob - Class in com.linkedin.venice.hadoop.spark.datawriter.jobs
The implementation of DataWriterComputeJob for Spark engine.
AbstractDataWriterSparkJob() - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
AbstractDataWriterTask - Class in com.linkedin.venice.hadoop.task.datawriter
AbstractDataWriterTask() - Constructor for class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
AbstractHttp2StreamFrameCodec - Class in com.linkedin.alpini.netty4.http2
A copy of the netty Http2StreamFrameToHttpObjectCodec except with the methods which actually return the converted objects have been made abstract.
AbstractHttp2StreamFrameCodec(boolean) - Constructor for class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
AbstractInputRecordProcessor<INPUT_KEY,​INPUT_VALUE> - Class in com.linkedin.venice.hadoop.task.datawriter
An abstraction of the task that processes each record from the input, and returns serialized, and potentially compressed, Avro key/value pairs.
AbstractInputRecordProcessor() - Constructor for class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
 
AbstractKafkaConsumerService - Class in com.linkedin.davinci.kafka.consumer
 
AbstractKafkaConsumerService() - Constructor for class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
AbstractPartitionStateModel - Class in com.linkedin.davinci.helix
An abstraction of Helix State model behavior registry that defines how participants (Storage node) fetch data from Kafka.
AbstractPartitionStateModel(VeniceIngestionBackend, ReadOnlyStoreRepository, VeniceStoreVersionConfig, int, CompletableFuture<HelixPartitionStatusAccessor>, String) - Constructor for class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
AbstractPartitionWriter - Class in com.linkedin.venice.hadoop.task.datawriter
An abstraction of the task that processes all key/value pairs, checks for duplicates and emits the final key/value pairs to Venice's PubSub.
AbstractPartitionWriter() - Constructor for class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
AbstractPartitionWriter.DuplicateKeyPrinter - Class in com.linkedin.venice.hadoop.task.datawriter
Using Avro Json encoder to print duplicate keys in case there are tons of duplicate keys, only print first AbstractPartitionWriter.DuplicateKeyPrinter.MAX_NUM_OF_LOG of them so that it won't pollute Reducer's log.
AbstractPartitionWriter.PartitionWriterProducerCallback - Class in com.linkedin.venice.hadoop.task.datawriter
 
AbstractPartitionWriter.VeniceWriterMessage - Class in com.linkedin.venice.hadoop.task.datawriter
 
AbstractPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
A base class which encapsulates the common plumbing needed by all PollStrategy implementations.
AbstractPollStrategy(boolean) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.AbstractPollStrategy
 
AbstractPollStrategy(boolean, int) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.AbstractPollStrategy
 
AbstractPushMonitor - Class in com.linkedin.venice.pushmonitor
AbstractPushMonitor is a high level abstraction that manages OfflinePushStatus.
AbstractPushMonitor(String, OfflinePushAccessor, StoreCleaner, ReadWriteStoreRepository, RoutingDataRepository, AggPushHealthStats, RealTimeTopicSwitcher, ClusterLockManager, String, List<String>, HelixAdminClient, VeniceControllerConfig, PushStatusStoreReader, DisabledPartitionStats) - Constructor for class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
AbstractQOS - Class in com.linkedin.alpini.base.queuing
Created by acurtis on 7/27/17.
AbstractQOS(Map<QOS, Integer>) - Constructor for class com.linkedin.alpini.base.queuing.AbstractQOS
 
AbstractQOSBasedQueue<T extends QOSBasedRequestRunnable> - Class in com.linkedin.alpini.base.queuing
Abstract base class for QOS priority queues.
AbstractQOSBasedQueue(Map<QOS, Integer>) - Constructor for class com.linkedin.alpini.base.queuing.AbstractQOSBasedQueue
 
AbstractQuantileEstimation<SAMPLE extends AbstractQuantileEstimation.AbstractSample<SAMPLE>> - Class in com.linkedin.alpini.base.statistics
A memory efficient abstract implementation for calculating quantile summaries.
AbstractQuantileEstimation(double, int) - Constructor for class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
AbstractQuantileEstimation(double, int, ConcurrentAccumulator.Mode) - Constructor for class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
AbstractQuantileEstimation.AbstractSample<SAMPLE extends AbstractQuantileEstimation.AbstractSample<SAMPLE>> - Class in com.linkedin.alpini.base.statistics
 
AbstractQuantileEstimation.Data - Class in com.linkedin.alpini.base.statistics
 
AbstractQuantileEstimation.Quantile - Class in com.linkedin.alpini.base.statistics
 
AbstractQuantileEstimation.Quantiles - Class in com.linkedin.alpini.base.statistics
 
AbstractRecordStreamDecoder<ENVELOPE,​K,​V> - Class in com.linkedin.venice.client.store.streaming
Streaming callback for batch-get/compute.
AbstractRecordStreamDecoder(List<K>, TrackingStreamingCallback<K, V>, Executor) - Constructor for class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
AbstractRoute - Class in com.linkedin.venice.controller.server
 
AbstractRoute(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.AbstractRoute
Default constructor for different controller request routes.
AbstractSample() - Constructor for class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.AbstractSample
 
AbstractSchemaEntrySerializer<T extends GeneratedSchemaEntry> - Class in com.linkedin.venice.helix
 
AbstractSchemaEntrySerializer() - Constructor for class com.linkedin.venice.helix.AbstractSchemaEntrySerializer
 
AbstractShutdownableResource<R> - Class in com.linkedin.alpini.base.registry
A simplified implementation of a ShutdownableResource.
AbstractShutdownableResource(R) - Constructor for class com.linkedin.alpini.base.registry.AbstractShutdownableResource
 
AbstractStateModelFactory - Class in com.linkedin.davinci.helix
ModelFactory manages Helix state model creation.
AbstractStateModelFactory(VeniceIngestionBackend, VeniceConfigLoader, ExecutorService, ParticipantStateTransitionStats, ReadOnlyStoreRepository, CompletableFuture<HelixPartitionStatusAccessor>, String) - Constructor for class com.linkedin.davinci.helix.AbstractStateModelFactory
 
AbstractStorageEngine<Partition extends AbstractStoragePartition> - Class in com.linkedin.davinci.store
A base storage abstract class which is actually responsible for data persistence.
AbstractStorageEngine(String, InternalAvroSpecificSerializer<StoreVersionState>, InternalAvroSpecificSerializer<PartitionState>) - Constructor for class com.linkedin.davinci.store.AbstractStorageEngine
 
AbstractStoragePartition - Class in com.linkedin.davinci.store
An abstract implementation of a storage partition.
AbstractStoragePartition(Integer) - Constructor for class com.linkedin.davinci.store.AbstractStoragePartition
 
AbstractStore - Class in com.linkedin.venice.meta
This is an abstraction of metadata maintained per Store.
AbstractStore() - Constructor for class com.linkedin.venice.meta.AbstractStore
 
AbstractStore.StoreVersionSupplier - Interface in com.linkedin.venice.meta
 
AbstractStoreBufferService - Class in com.linkedin.davinci.kafka.consumer
Abstract class capturing the responsibilities of drainers threads doing store ingestion.
AbstractStoreBufferService() - Constructor for class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
 
AbstractStoreMetadata - Class in com.linkedin.venice.fastclient.meta
 
AbstractStoreMetadata(ClientConfig) - Constructor for class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
AbstractVeniceAggStats<T extends AbstractVeniceStats> - Class in com.linkedin.venice.stats
 
AbstractVeniceAggStats(MetricsRepository) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStats
 
AbstractVeniceAggStats(MetricsRepository, StatsSupplier<T>) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStats
 
AbstractVeniceAggStats(String, MetricsRepository, StatsSupplier<T>) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStats
 
AbstractVeniceAggStoreStats<T extends AbstractVeniceStats> - Class in com.linkedin.venice.stats
This class is an aggregate place that keeps stats objects for multiple stores.
AbstractVeniceAggStoreStats(MetricsRepository, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStoreStats
 
AbstractVeniceAggStoreStats(MetricsRepository, StatsSupplier<T>, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStoreStats
 
AbstractVeniceAggStoreStats(String, MetricsRepository, StatsSupplier<T>, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStoreStats
 
AbstractVeniceAggVersionedStats<STATS,​STATS_REPORTER extends AbstractVeniceStatsReporter<STATS>> - Class in com.linkedin.davinci.stats
 
AbstractVeniceAggVersionedStats(MetricsRepository, ReadOnlyStoreRepository, Supplier<STATS>, StatsSupplier<STATS_REPORTER>, boolean) - Constructor for class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
AbstractVeniceFilter<INPUT_VALUE> - Class in com.linkedin.venice.hadoop
An abstraction to filter given data type.
AbstractVeniceFilter() - Constructor for class com.linkedin.venice.hadoop.AbstractVeniceFilter
 
AbstractVeniceHttpStats - Class in com.linkedin.venice.stats
 
AbstractVeniceHttpStats(MetricsRepository, String, RequestType) - Constructor for class com.linkedin.venice.stats.AbstractVeniceHttpStats
 
AbstractVeniceMapper<INPUT_KEY,​INPUT_VALUE> - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.map
An abstraction of the mapper that would return serialized, and potentially compressed, Avro key/value pairs.
AbstractVeniceMapper() - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.map.AbstractVeniceMapper
 
AbstractVeniceProducer<K,​V> - Class in com.linkedin.venice.producer
A generic implementation of the VeniceProducer interface
AbstractVeniceProducer() - Constructor for class com.linkedin.venice.producer.AbstractVeniceProducer
 
AbstractVeniceRecordReader<INPUT_KEY,​INPUT_VALUE> - Class in com.linkedin.venice.hadoop.input.recordreader
An abstraction for a record reader that reads records from the configured input into Avro-serialized keys and values.
AbstractVeniceRecordReader() - Constructor for class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
 
AbstractVeniceService - Class in com.linkedin.venice.service
Blueprint for all Services initiated from Venice Server
AbstractVeniceService() - Constructor for class com.linkedin.venice.service.AbstractVeniceService
 
AbstractVeniceService.ServiceState - Enum in com.linkedin.venice.service
 
AbstractVeniceStats - Class in com.linkedin.venice.stats
 
AbstractVeniceStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.AbstractVeniceStats
 
AbstractVeniceStatsReporter<STATS> - Class in com.linkedin.davinci.stats
 
AbstractVeniceStatsReporter(MetricsRepository, String) - Constructor for class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
 
AbstractVeniceWriter<K,​V,​U> - Class in com.linkedin.venice.writer
A base class which users of VeniceWriter can leverage in order to make unit tests easier.
AbstractVeniceWriter(String) - Constructor for class com.linkedin.venice.writer.AbstractVeniceWriter
 
AbstractVsonSchemaAdapter<T> - Class in com.linkedin.venice.schema.vson
Deprecated.
accept(double) - Method in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation
 
accept(double) - Method in class com.linkedin.alpini.base.statistics.Welfords
 
accept(long) - Method in class com.linkedin.alpini.base.statistics.LongQuantileEstimation
 
accept(long) - Method in class com.linkedin.alpini.base.statistics.Welfords.LongWelford
 
accept(SAMPLE) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
accept(T) - Method in class com.linkedin.alpini.base.concurrency.ComplexAccumulator
Adds the given value.
accept(T) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
Adds the given value.
accept(T) - Method in class com.linkedin.alpini.base.concurrency.ThreadedAccumulator
 
accept(T) - Method in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation
 
acceptBoundary(String) - Method in class com.linkedin.alpini.netty4.handlers.HttpContentUnwrap
 
acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
acceptEither(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
acceptEitherAsync(CompletionStage<? extends V>, Consumer<? super V>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
acceptInboundMessage(Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpContentUnwrap
 
acceptInboundMessage(Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
acceptInboundMessage(Object) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
acceptInboundMessage(Object) - Method in class io.netty.handler.codec.EspressoMessageAggregator
 
acceptInboundMessage(Object) - Method in class io.netty.handler.codec.EspressoMessageToMessageDecoder
Returns true if the given message should be handled.
acceptOutboundMessage(Object) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.EspressoMessageToMessageEncoder
 
acceptOutboundMessage(Object) - Method in class io.netty.handler.codec.http.EspressoHttpObjectEncoder
 
ACCESS_CONTROL - com.linkedin.venice.Arg
 
ACCESS_CONTROLLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
ACCESS_PERMISSION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
accessControlled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
accessControlled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
accessControlled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Store-level ACL switch.
AccessController - Interface in com.linkedin.venice.acl
An AccessController allows a request to be checked against an Access Control List (ACL).
accumulate(LongQuantileEstimation.Sample) - Method in class com.linkedin.alpini.base.statistics.LongStatsAggregator.LongData
 
AceEntry - Class in com.linkedin.venice.authorization
Represents an Access Control Entry.
AceEntry(Principal, Method, Permission) - Constructor for class com.linkedin.venice.authorization.AceEntry
Creates an Access Control entry
ACL_CHECK_FAILURE_WARN_MESSAGE_PREFIX - Static variable in class com.linkedin.venice.controller.server.VeniceRouteHandler
 
ACL_PERMS - com.linkedin.venice.Arg
 
AclBinding - Class in com.linkedin.venice.authorization
Represents an Access Control Binding.
AclBinding(Resource) - Constructor for class com.linkedin.venice.authorization.AclBinding
Creates an Access Control Binding for a given resource with empty AceEntries.
AclCreationDeletionListener - Class in com.linkedin.venice.acl
Update access controller resource list when a store is created/deleted
AclCreationDeletionListener(DynamicAccessController) - Constructor for class com.linkedin.venice.acl.AclCreationDeletionListener
 
AclException - Exception in com.linkedin.venice.acl
 
AclException() - Constructor for exception com.linkedin.venice.acl.AclException
 
AclException(String) - Constructor for exception com.linkedin.venice.acl.AclException
 
AclException(String, Throwable) - Constructor for exception com.linkedin.venice.acl.AclException
 
AclException(String, Throwable, boolean, boolean) - Constructor for exception com.linkedin.venice.acl.AclException
 
AclException(Throwable) - Constructor for exception com.linkedin.venice.acl.AclException
 
AclResponse - Class in com.linkedin.venice.controllerapi
 
AclResponse() - Constructor for class com.linkedin.venice.controllerapi.AclResponse
 
acquire() - Method in interface com.linkedin.alpini.base.pool.AsyncPool
 
acquire() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
acquire() - Method in class com.linkedin.alpini.base.pool.impl.AsyncQOSPoolImpl
 
acquire() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
 
acquire() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
acquire() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
acquire(EventLoop, String, String, QOS) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
Acquire a channel from the pool.
acquire(EventLoop, String, String, QOS) - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
acquire(EventLoop, String, String, QOS) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
acquire(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
acquire(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
 
acquire(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
acquire(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
acquire(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
acquire(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
acquire(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
acquire(String, QOS) - Method in interface com.linkedin.alpini.base.pool.AsyncQOSPool
 
acquire(String, QOS) - Method in class com.linkedin.alpini.base.pool.impl.AsyncQOSPoolImpl
 
acquire(String, String, QOS) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
Acquire a channel from the pool.
acquire(String, String, QOS) - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
acquire(String, String, QOS) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
acquire0() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
acquire0(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
acquire0(String, QOS) - Method in class com.linkedin.alpini.base.pool.impl.AsyncQOSPoolImpl
 
acquireConnectSemaphore() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
acquireConnectSemaphore() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
acquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
Returns the number of acquired channels that this pool thinks it has.
acquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Returns the number of acquired channels that this pool thinks it has.
acquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
acquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
ACTION_DISABLE - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
ACTION_ENABLE - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
ACTIVE_ACTIVE - com.linkedin.venice.meta.DataReplicationPolicy
Samza job per colo pushes to local real-time topic.
ACTIVE_ACTIVE_ENABLED_ON_CONTROLLER - Static variable in class com.linkedin.venice.ConfigKeys
Whether A/A is enabled on the controller.
ACTIVE_ACTIVE_NOT_ENABLED - com.linkedin.venice.stats.StatsErrorCode
This metric should not be emitted as it is a metric specific to an A/A store.
ACTIVE_ACTIVE_REAL_TIME_SOURCE_FABRIC_LIST - Static variable in class com.linkedin.venice.ConfigKeys
A list of fabrics that are source(s) of the active active real time replication.
ACTIVE_ACTIVE_REPLICATION_ENABLED - com.linkedin.venice.Arg
 
ACTIVE_ACTIVE_REPLICATION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
ACTIVE_ELEM_TS_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
ACTIVE_ELEM_TS_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
Client readable elements that haven't been deleted yet.
ActiveActiveProducerCallback - Class in com.linkedin.davinci.kafka.consumer
 
ActiveActiveProducerCallback(LeaderFollowerStoreIngestionTask, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, LeaderProducedRecordContext, int, String, long) - Constructor for class com.linkedin.davinci.kafka.consumer.ActiveActiveProducerCallback
 
activeActiveReplicationEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
A command option to enable/disable Active/Active replication feature for a store
activeActiveReplicationEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not active/active replication is enabled for hybrid stores; eventually this config will replace native replication flag, when all stores are on A/A
activeActiveReplicationEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Whether or not active/active replication is enabled for hybrid stores; eventually this config will replace native replication flag, when all stores are on A/A
ActiveActiveStoreIngestionTask - Class in com.linkedin.davinci.kafka.consumer
This class contains logic that SNs must perform if a store-version is running in Active/Active mode.
ActiveActiveStoreIngestionTask(StoreIngestionTaskFactory.Builder, Store, Version, Properties, BooleanSupplier, VeniceStoreVersionConfig, int, boolean, Optional<ObjectCacheBackend>, Function<Integer, DaVinciRecordTransformer>) - Constructor for class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
activeAllocations() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocatorMetric
 
activeStreamsCountHandler(ActiveStreamsCountHandler) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
ActiveStreamsCountHandler - Class in io.netty.handler.codec.http2
Counts the number of the active HTTP/2 Streams
ActiveStreamsCountHandler() - Constructor for class io.netty.handler.codec.http2.ActiveStreamsCountHandler
 
activeThreadCount() - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
 
adapt(TimeoutProcessor) - Static method in interface com.linkedin.alpini.router.api.RouterTimeoutProcessor
 
adapt(PartitionFinder<K>, Executor) - Static method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
 
adapt(Schema, Object) - Method in interface com.linkedin.venice.schema.SchemaAdapter
 
adaptSSLFactory(SslFactory) - Static method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
 
adaptToSchema(Schema, Object) - Static method in interface com.linkedin.venice.schema.SchemaAdapter
Checks if it is possible for some value to be modified to adapt to the provided schema type.
add(int, E) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
add(int, E) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
add(long) - Method in class com.linkedin.davinci.utils.StoragePartitionDiskUsage
Adds a usage size to the partition
add(TimeValue) - Method in class com.linkedin.alpini.base.misc.TimeValue
 
add(AbstractVeniceFilter<INPUT_VALUE>) - Method in class com.linkedin.venice.hadoop.FilterChain
 
add(PubSubMessageHeader) - Method in class com.linkedin.venice.pubsub.api.EmptyPubSubMessageHeaders
 
add(PubSubMessageHeader) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
 
add(E) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
add(E) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
add(E) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
add(ByteBuf) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Add a buffer to the end of the queue.
add(ByteBuf, ChannelFutureListener) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Add a buffer to the end of the queue and associate a listener with it that should be completed when all the buffers bytes have been consumed from the queue and written.
add(ByteBuf, ChannelPromise) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Add a buffer to the end of the queue and associate a promise with it that should be completed when all the buffer's bytes have been consumed from the queue and written.
add(HttpHeaders) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
add(CharSequence, int) - Method in interface com.linkedin.alpini.base.misc.Headers
 
add(CharSequence, int) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
add(CharSequence, long) - Method in interface com.linkedin.alpini.base.misc.Headers
 
add(CharSequence, Iterable<?>) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
add(CharSequence, Object) - Method in interface com.linkedin.alpini.base.misc.Headers
 
add(CharSequence, Object) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
add(CharSequence, Object) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
add(String, byte[]) - Method in class com.linkedin.venice.pubsub.api.EmptyPubSubMessageHeaders
 
add(String, byte[]) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
 
add(String, Boolean) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
add(String, Integer) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
add(String, Iterable<?>) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
add(String, Long) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
add(String, Object) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
add(String, String) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
add(String, Optional<TYPE>) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
add(T) - Method in class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
add(T) - Method in class com.linkedin.alpini.base.queuing.QOSBasedQueue
 
add(T) - Method in class com.linkedin.alpini.base.queuing.QOSFCFSQueue
 
add(T) - Method in interface com.linkedin.alpini.base.queuing.SimpleQueue
 
add(T) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
add(T) - Method in class com.linkedin.venice.utils.ExpiringSet
 
add(T, long, TimeUnit) - Method in class com.linkedin.venice.utils.ExpiringSet
 
ADD_DERIVED_SCHEMA - com.linkedin.venice.Command
 
ADD_DERIVED_SCHEMA - com.linkedin.venice.controllerapi.ControllerRoute
 
ADD_NULL_TO_UNION - com.linkedin.venice.etl.ETLValueSchemaTransformation
 
ADD_SCHEMA - com.linkedin.venice.Command
 
ADD_SCHEMA_TO_ZK - com.linkedin.venice.Command
 
ADD_TO_STORE_ACL - com.linkedin.venice.Command
 
ADD_VALUE_SCHEMA - com.linkedin.venice.authorization.Method
 
ADD_VALUE_SCHEMA - com.linkedin.venice.controllerapi.ControllerRoute
 
ADD_VERSION - com.linkedin.venice.authorization.Method
 
ADD_VERSION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
ADD_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
addAce(Resource, AceEntry) - Method in interface com.linkedin.venice.authorization.AuthorizerService
This will add a single AceEntry to the existing AceEntries for a resource.
addAce(Resource, AceEntry) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
addAceEntries(Collection<AceEntry>) - Method in class com.linkedin.venice.authorization.AclBinding
Add a list of AceEntry to the existing list of Aces.
addAceEntry(AceEntry) - Method in class com.linkedin.venice.authorization.AclBinding
Add one AceEntry to the existing list of Aces.
addAcl(String) - Method in interface com.linkedin.venice.acl.DynamicAccessController
Add a resource to the resource list.
addAfter(C, ChannelHandler...) - Method in class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
addAfter(C, EventExecutorGroup, String, ChannelHandler) - Method in class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
addAfter(C, String, ChannelHandler) - Method in class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
addAfter(ChannelHandler...) - Method in class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
addAfter(EventExecutorGroup, ChannelHandler...) - Method in class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
addAfter(EventExecutorGroup, String, ChannelHandler) - Method in class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
addAfter(String, ChannelHandler) - Method in class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
addAll(int, Collection<? extends E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
addAll(int, Collection<? extends E>) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
addAll(ComplementSet<T>) - Method in class com.linkedin.venice.utils.ComplementSet
 
addAll(Collection<? extends E>) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
addAll(Collection<? extends E>) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
addAll(Collection<? extends E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
addAll(Collection<? extends T>) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
addAllAbsent(Collection<? extends E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
addBeforeChunkAggregator(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.Router.PipelineFactory
 
addBeforeChunkAggregator(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.RouterPipelineFactory
 
addBeforeChunkAggregator(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
addBeforeChunkAggregator(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
addBeforeChunkAggregator(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBeforeChunkAggregator(Consumer<ChannelPipeline>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBeforeHttpRequestHandler(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.Router.PipelineFactory
 
addBeforeHttpRequestHandler(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.RouterPipelineFactory
 
addBeforeHttpRequestHandler(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
addBeforeHttpRequestHandler(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
addBeforeHttpRequestHandler(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBeforeHttpRequestHandler(Consumer<ChannelPipeline>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBeforeHttpServerCodec(String, Supplier<?>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
addBeforeHttpServerCodec(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.Router.PipelineFactory
 
addBeforeHttpServerCodec(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.RouterPipelineFactory
 
addBeforeHttpServerCodec(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
addBeforeHttpServerCodec(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBeforeHttpServerCodec(Consumer<ChannelPipeline>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBeforeIdleStateHandler(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.Router.PipelineFactory
 
addBeforeIdleStateHandler(String, Supplier<? extends CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.RouterPipelineFactory
 
addBeforeIdleStateHandler(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
addBeforeIdleStateHandler(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
addBeforeIdleStateHandler(String, Supplier<? extends ChannelHandler>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBeforeIdleStateHandler(Consumer<ChannelPipeline>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
addBootstrapFilter(Function<T, T>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
addBootstrapFilter(Function<T, T>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
addChannelToReadCompletePendingQueue() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
 
addChunkIntoContainer(CHUNKS_CONTAINER, int, byte[]) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
Used to incrementally add a {@param valueChunk} into the {@param CHUNKS_CONTAINER} container.
addChunkIntoContainer(ChunkedValueInputStream, int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
addChunkIntoContainer(CompositeByteBuf, int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
 
addChunkIntoContainer(ByteBuffer, int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
 
addClusterConfig(VeniceControllerConfig) - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
addClusterfigChangeListener(ClusterConfigChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addClusterToGrandCluster(String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Add the specified cluster as a resource to the grand cluster to be managed by HaaS controllers.
addClusterToGrandCluster(String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
addConfigChangeListener(ScopedConfigChangeListener, HelixConfigScope.ConfigScopeProperty) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addConnectionPoolManager(PoolingNHttpClientConnectionManager) - Method in class com.linkedin.venice.stats.HttpConnectionPoolStats
 
addControllerListener(ControllerChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addControllerMessageListener(MessageListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addCurrentStateChangeListener(CurrentStateChangeListener, String, String) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addDatabaseLookupLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
addDerivedSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
 
addDerivedSchema(DerivedSchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
 
addDerivedSchema(String, int, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
addDerivedSchema(String, int, String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
addDerivedSchema(String, DerivedSchemaEntry) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
addDerivedSchema(String, String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
addDerivedSchema(String, String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
addDerivedSchema(String, String, int) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
Add a new derived schema for the given store and value schema id
addDerivedSchema(String, String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
addDerivedSchema(String, String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
addDerivedSchema(String, String, int, int) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
Add a new derived schema for the given store by specifying derived schema id.
addDerivedSchema(String, String, int, int, String) - Method in interface com.linkedin.venice.controller.Admin
This method skips most precondition checks and is intended for only internal use.
addDerivedSchema(String, String, int, int, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Add a new derived schema for the given store with all specified properties.
addDerivedSchema(String, String, int, int, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
addDerivedSchema(String, String, int, String) - Method in interface com.linkedin.venice.controller.Admin
 
addDerivedSchema(String, String, int, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Add a new derived schema for the given store with all specified properties and return a new DerivedSchemaEntry object containing the schema and its id.
addDerivedSchema(String, String, int, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Add a new superset schema for the given store with all specified properties by sending a DERIVED_SCHEMA_CREATION admin message.
addExternalViewChangeListener(ExternalViewChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addFilledSize(int) - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
 
addFirst(E) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Inserts the specified element at the beginning of this list.
addFirst(ByteBuf, ChannelPromise) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Add a buffer to the front of the queue and associate a promise with it that should be completed when all the buffer's bytes have been consumed from the queue and written.
addFollowerLagMonitor(Version, int) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
Adds monitoring for a follower partition of a given version.
addHandler(VeniceServerGrpcHandler) - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcRequestProcessor
 
addIdealStateChangeListener(IdealStateChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addIngestionIsolationToProperties(Properties) - Static method in class com.linkedin.venice.utils.TestUtils
 
addIngestionNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
addIngestionNotifier(VeniceNotifier) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
 
addIngestionNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
addIngestionNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
addIngestionNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
addIngestionNotifier(VeniceNotifier) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Adds Notifier to get Notifications for get various status of the consumption tasks like start, completed, progress and error states.
addInstanceConfigChangeListener(InstanceConfigChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addInstanceToAllowlist(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
addInstanceToAllowlist(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Add the given helix nodeId into the allowlist in ZK.
addInstanceToAllowlist(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
addInstanceToAllowList(String, String) - Method in interface com.linkedin.venice.helix.AllowlistAccessor
Add the given helix nodeId into the allowlist in ZK.
addInstanceToAllowList(String, String) - Method in class com.linkedin.venice.helix.ZkAllowlistAccessor
Add the given helix nodeId into the allowlist in ZK.
addInt(CharSequence, int) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
addLast(E) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Appends the specified element to the end of this list.
addLeaderLagMonitor(Version, int) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
Adds monitoring for a leader partition of a given version.
addListener(AsyncFutureListener<T>) - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Adds the specified listener to this future.
addListener(AsyncFutureListener<T>) - Method in interface com.linkedin.alpini.base.concurrency.AsyncPromise
Adds the specified listener to this future.
addListener(AsyncFutureListener<T>) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
addListener(AsyncFutureListener<T>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Adds the specified listener to this future.
addListener(AsyncFutureListener<T>) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Adds the specified listener to this future.
addListener(AsyncPromise<T>) - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Adds the specified future as a listener to this future.
addListener(AsyncPromise<T>) - Method in interface com.linkedin.alpini.base.concurrency.AsyncPromise
Adds the specified future as a listener to this future.
addListener(AsyncPromise<T>) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
Adds the specified future as a listener to this future.
addListener(AsyncPromise<T>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Adds the specified future as a listener to this future.
addListener(AsyncPromise<T>) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Adds the specified future as a listener to this future.
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
addListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.bootstrap.PendingConnectPromise
 
addListener(GenericFutureListener<? extends Future<? super V>>) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
addListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.bootstrap.PendingConnectPromise
 
addListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
addLiveInstanceChangeListener(LiveInstanceChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addLocalStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.storage.StorageEngineRepository
 
addMessageListener(MessageListener, String) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addMetric(TehutiMetric) - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
addMilliseconds(long) - Method in class com.linkedin.venice.utils.TestMockTime
 
addNextHandler(VeniceServerGrpcHandler) - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
 
addNodeIntoAllowList(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
 
addNodeIntoAllowList(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
addOfflineRequest(ScatterGatherRequest<H, K>) - Method in class com.linkedin.alpini.router.api.Scatter
 
addOnlineRequest(ScatterGatherRequest<H, K>) - Method in class com.linkedin.alpini.router.api.Scatter
 
addOptionalChannelHandler(String, ChannelHandler) - Method in class com.linkedin.venice.router.RouterServer
 
addPartition(Partition) - Method in class com.linkedin.venice.meta.PartitionAssignment
 
addPartitionConsumptionState(PartitionConsumptionState) - Method in class com.linkedin.davinci.listener.response.AdminResponse
Add a partition consumption state to the admin response record
addPartitionConsumptionState(Integer, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
addPartitionDetails(OfflinePushStatus) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
addPartitionNameToQuery(String) - Method in class com.linkedin.alpini.router.api.BroadcastScatterGatherRequest
 
addPersona(String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
Creates a new persona with the given parameters.
addPingTasks(List<CompletableFuture<?>>, ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Http2PingResponseHandler
 
addPreConnectCallback(PreConnectCallback) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addPropertyDiff(String, String, String, String, String) - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
 
addPushStatusNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
addPushStatusNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
addPushStatusNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
addPushStatusNotifier(VeniceNotifier) - Method in interface com.linkedin.davinci.ingestion.VeniceIngestionBackend
Adds ingestion listener which reports ingestion status for different push monitors.
addReadComputeDeserializationLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
addReadComputeLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
addReadComputeOutputSize(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
addReadComputeSerializationLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
addRecord(K) - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
addReplicationMetadataSchema(RmdSchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
 
addReplicationMetadataSchema(String, int, String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
addReplicationMetadataSchema(String, int, String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
addReplicationMetadataSchema(String, int, String, int) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
 
addReplicationMetadataSchema(String, RmdSchemaEntry) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
addReplicationMetadataSchema(String, String, int, int, String) - Method in interface com.linkedin.venice.controller.Admin
 
addReplicationMetadataSchema(String, String, int, int, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Create a new ReplicationMetadataSchemaEntry object with the given properties and add it into schema repository if no duplication.
addReplicationMetadataSchema(String, String, int, int, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Create a new ReplicationMetadataSchemaEntry object with the given properties and add it into schema repository by sending REPLICATION_METADATA_SCHEMA_CREATION admin message.
addResourceConfigChangeListener(ResourceConfigChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addSchemaDiff(String, String, String, String, String) - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
 
addServerConfigs(Properties) - Method in class com.linkedin.davinci.listener.response.AdminResponse
Load all server configs into admin response record
addShort(CharSequence, short) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
addSpecificVersion(String, String, Version) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
TODO refactor addVersion to these broken down methods instead of doing everything in one giant method.
addStatsForRoute(String) - Method in class com.linkedin.venice.stats.HttpConnectionPoolStats
This function is used to gradually populate per-route stats.
addStoragePartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
addStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
addStore(Store) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
addStore(Store) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepositoryAdapter
This function only be used to add regular venice store, and the system store is bundled with regular venice store.
addStore(Store) - Method in interface com.linkedin.venice.meta.ReadWriteStoreRepository
Add store into repository.
addStore(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
addStoresToPersona(String, List<String>) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
This operation assumes that stores which are added to the persona are not contained within any store, but does not do any validity checks.
addStoreVersionState(StoreVersionState) - Method in class com.linkedin.davinci.listener.response.AdminResponse
Add store version state metadata into the admin response record
addSupersetSchema(String, String, String, int, String, int) - Method in interface com.linkedin.venice.controller.Admin
 
addSupersetSchema(String, String, String, int, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Add a new superset schema for the given store with all specified properties.
addSupersetSchema(String, String, String, int, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
addTargetExternalViewChangeListener(ExternalViewChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
addToCheckSum(KafkaKey, KafkaMessageEnvelope) - Method in class com.linkedin.venice.kafka.validation.Segment
This function updates the running checksum as follows, depending on the MessageType: 1.
addToSupposedlyOngoingIncrementalPushVersions(String, int, String, ExecutionStatus) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
addUpdateSchemaForStore(VeniceParentHelixAdmin, String, String, boolean) - Static method in class com.linkedin.venice.controller.util.ParentControllerConfigUpdateUtils
 
addValueSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
Route to handle adding value schema request.
addValueSchema(SchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
 
addValueSchema(String, SchemaEntry) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
addValueSchema(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
addValueSchema(String, String) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
Add a new value schema for the given store
addValueSchema(String, String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
addValueSchema(String, String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
addValueSchema(String, String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
addValueSchema(String, String, int) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
Add a new value schema for the given store by specifying schema id.
addValueSchema(String, String, int, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
addValueSchema(String, String, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
Add new value schema for the given store.
addValueSchema(String, String, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
addValueSchema(String, String, DirectionalSchemaCompatibilityType) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
Add a new value schema for the given store
addValueSchema(String, String, String, int) - Method in interface com.linkedin.venice.controller.Admin
This method skips most precondition checks and is intended for only internal use.
addValueSchema(String, String, String, int, DirectionalSchemaCompatibilityType) - Method in interface com.linkedin.venice.controller.Admin
 
addValueSchema(String, String, String, int, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Add a new value schema for the given store with all specified properties and return a new SchemaEntry object containing the schema and its id.
addValueSchema(String, String, String, int, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
addValueSchema(String, String, String, DirectionalSchemaCompatibilityType) - Method in interface com.linkedin.venice.controller.Admin
 
addValueSchema(String, String, String, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
addValueSchema(String, String, String, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Add a new value schema for the given store with all specified properties by sending a VALUE_SCHEMA_CREATION admin message.
addValueSize(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
addVeniceStorageClusterToControllerCluster(String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Add the given Venice storage cluster's cluster resource to the controller cluster.
addVeniceStorageClusterToControllerCluster(String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
addVersion(int) - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
addVersion(int) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
addVersion(Version) - Method in class com.linkedin.venice.meta.AbstractStore
 
addVersion(Version) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
addVersion(Version) - Method in interface com.linkedin.venice.meta.Store
 
addVersion(Version, boolean) - Method in class com.linkedin.venice.meta.AbstractStore
 
addVersion(Version, boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
addVersion(Version, boolean) - Method in interface com.linkedin.venice.meta.Store
 
AddVersion - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
AddVersion() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Default constructor.
AddVersion(CharSequence, CharSequence, CharSequence, Integer, Integer, Integer, CharSequence, Long, Integer, Boolean, List<CharSequence>) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
All-args constructor.
addVersionAndStartIngestion(Admin) - Method in class com.linkedin.venice.controller.server.CreateVersion
This function is only being used by store migration parent controllers, which write add version admin message.
addVersionAndStartIngestion(String, String, int, int, Version.PushType, String, long, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
Used for store migration to add version and start ingestion in destination cluster for new pushes in the source cluster during the ingestion.
addVersionAndStartIngestion(String, String, String, int, int, Version.PushType, String, long, int, boolean) - Method in interface com.linkedin.venice.controller.Admin
This method behaves differently in VeniceHelixAdmin and VeniceParentHelixAdmin.
addVersionAndStartIngestion(String, String, String, int, int, Version.PushType, String, long, int, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
This is a wrapper for VeniceHelixAdmin#addVersion but performs additional operations needed for add version invoked from the admin channel.
addVersionAndStartIngestion(String, String, String, int, int, Version.PushType, String, long, int, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
addVersionAndTopicOnly(String, String, String, int, int, int, boolean, boolean, Version.PushType, String, String, Optional<String>, long, int, Optional<String>, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
addVersionAndTopicOnly(String, String, String, int, int, int, boolean, boolean, Version.PushType, String, String, Optional<String>, long, int, Optional<String>, boolean, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
A wrapper to invoke VeniceHelixAdmin#addVersion to only increment the version and create the topic(s) needed without starting ingestion.
addVersionOnly(String, String, String, int, int, Version.PushType, String, long, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Only add version to the store without creating the topic or start ingestion.
addVersionStateDiff(String, String, int, VersionStatus, VersionStatus) - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
 
addWaiter(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
adjustStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Adjust the opened storage partition according to the provided storagePartitionConfig.
ADLER32 - com.linkedin.venice.kafka.validation.checksum.CheckSumType
Deprecated.
Adler32CheckSum - Class in com.linkedin.venice.kafka.validation.checksum
Running checksum implementations based on Adler32.
Adler32CheckSum() - Constructor for class com.linkedin.venice.kafka.validation.checksum.Adler32CheckSum
 
Admin - Interface in com.linkedin.venice.controller
 
ADMIN - com.linkedin.venice.meta.QueryAction
 
ADMIN_CHECK_READ_METHOD_FOR_KAFKA - Static variable in class com.linkedin.venice.ConfigKeys
Whether controller should check "Read" method against Kafka wildcard ACL while users request for a topic to write.
ADMIN_CONSUMPTION_CYCLE_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
The maximum time allowed for worker threads to execute admin messages in one cycle.
ADMIN_CONSUMPTION_MAX_WORKER_THREAD_POOL_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
The maximum number of threads allowed in the pool for executing admin messages.
ADMIN_CONSUMPTION_TIMEOUT_MINUTES - Static variable in class com.linkedin.venice.ConfigKeys
If there is a failure in consuming from the admin topic, skip the message after retrying for this many minutes Default 5 days
ADMIN_HELIX_MESSAGING_CHANNEL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Flag to enable the controller to send kill push job helix messages to the storage node upon consuming kill push job admin messages.
ADMIN_HOSTNAME - Static variable in class com.linkedin.venice.ConfigKeys
 
ADMIN_OPERATION - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode metadata changes about the system as a whole.
ADMIN_PORT - Static variable in class com.linkedin.venice.ConfigKeys
 
ADMIN_SECURE_PORT - Static variable in class com.linkedin.venice.ConfigKeys
 
ADMIN_TOPIC - com.linkedin.venice.pubsub.api.PubSubTopicType
 
ADMIN_TOPIC_PARTITION_ID - Static variable in class com.linkedin.venice.controller.kafka.AdminTopicUtils
 
ADMIN_TOPIC_PREFIX - Static variable in enum com.linkedin.venice.pubsub.api.PubSubTopicType
 
ADMIN_TOPIC_REMOTE_CONSUMPTION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether child controllers will directly consume the source admin topic in the parent Kafka cluster.
ADMIN_TOPIC_REPLICATION_FACTOR - Static variable in class com.linkedin.venice.ConfigKeys
The replication factor to set for admin topics.
ADMIN_TOPIC_SOURCE_REGION - Static variable in class com.linkedin.venice.ConfigKeys
This config defines the source region name of the admin topic
Admin.OfflinePushStatusInfo - Class in com.linkedin.venice.controller
 
adminCheckReadMethodForKafka() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
adminCheckReadMethodForKafka() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
AdminCommandExecution - Class in com.linkedin.venice.controllerapi
The execution object is a kind of context for a admin command including essential information used to track the status of this command.
AdminCommandExecution() - Constructor for class com.linkedin.venice.controllerapi.AdminCommandExecution
CTOR used by JSON serializer.
AdminCommandExecution(long, String, String, Collection<String>) - Constructor for class com.linkedin.venice.controllerapi.AdminCommandExecution
 
AdminCommandExecutionResponse - Class in com.linkedin.venice.controllerapi.routes
 
AdminCommandExecutionResponse() - Constructor for class com.linkedin.venice.controllerapi.routes.AdminCommandExecutionResponse
 
AdminCommandExecutionRoutes - Class in com.linkedin.venice.controller.server
 
AdminCommandExecutionRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.AdminCommandExecutionRoutes
 
AdminCommandExecutionStatus - Enum in com.linkedin.venice.controllerapi
 
AdminCommandExecutionTracker - Class in com.linkedin.venice.controller
This class is used to track the execution of the async admin command.
AdminCommandExecutionTracker(String, ExecutionIdAccessor, Map<String, ControllerClient>) - Constructor for class com.linkedin.venice.controller.AdminCommandExecutionTracker
 
AdminCommandExecutionTracker(String, ExecutionIdAccessor, Map<String, ControllerClient>, int) - Constructor for class com.linkedin.venice.controller.AdminCommandExecutionTracker
 
AdminConsumerService - Class in com.linkedin.venice.controller.kafka.consumer
One consumer service for one cluster.
AdminConsumerService(VeniceHelixAdmin, VeniceControllerConfig, MetricsRepository, PubSubTopicRepository, PubSubMessageDeserializer) - Constructor for class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
 
AdminConsumptionStats - Class in com.linkedin.venice.controller.stats
 
AdminConsumptionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
AdminConsumptionTask - Class in com.linkedin.venice.controller.kafka.consumer
This class is used to create a task, which will consume the admin messages from the special admin topics.
AdminConsumptionTask(String, PubSubConsumerAdapter, boolean, Optional<String>, VeniceHelixAdmin, AdminTopicMetadataAccessor, ExecutionIdAccessor, boolean, AdminConsumptionStats, int, Optional<Integer>, long, int, PubSubTopicRepository, PubSubMessageDeserializer, String) - Constructor for class com.linkedin.venice.controller.kafka.consumer.AdminConsumptionTask
 
AdminExecutionTask - Class in com.linkedin.venice.controller.kafka.consumer
This class is used to create Callable that execute AdminOperations for a given store.
AdminMessageType - Enum in com.linkedin.venice.controller.kafka.protocol.enums
 
adminOperation - Variable in class com.linkedin.venice.DumpAdminMessages.AdminOperationInfo
 
AdminOperation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
AdminOperation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
Default constructor.
AdminOperation(Integer, Long, Object) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
All-args constructor.
AdminOperationInfo() - Constructor for class com.linkedin.venice.DumpAdminMessages.AdminOperationInfo
 
AdminOperationSerializer - Class in com.linkedin.venice.controller.kafka.protocol.serializer
 
AdminOperationSerializer() - Constructor for class com.linkedin.venice.controller.kafka.protocol.serializer.AdminOperationSerializer
 
AdminOperationsHandler - Class in com.linkedin.venice.router
 
AdminOperationsHandler(AccessController, RouterServer, AdminOperationsStats) - Constructor for class com.linkedin.venice.router.AdminOperationsHandler
 
AdminOperationsStats - Class in com.linkedin.venice.router.stats
 
AdminOperationsStats(MetricsRepository, String, VeniceRouterConfig) - Constructor for class com.linkedin.venice.router.stats.AdminOperationsStats
 
AdminOperationWrapper - Class in com.linkedin.venice.controller.kafka.consumer
 
AdminRequest - Class in com.linkedin.venice.listener.request
AdminRequest encapsulates an admin request from server admin tools.
AdminResponse - Class in com.linkedin.davinci.listener.response
This class stores all the information required for answering a server admin request.
AdminResponse() - Constructor for class com.linkedin.davinci.listener.response.AdminResponse
 
AdminResponseRecord - Class in com.linkedin.venice.admin.protocol.response
Response record for admin request, version 1
AdminResponseRecord() - Constructor for class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Default constructor.
AdminResponseRecord(List<ConsumptionStateSnapshot>, Object, ServerConfigSnapshot) - Constructor for class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
All-args constructor.
AdminSparkServer - Class in com.linkedin.venice.controller.server
Controller admin API leveraging sparkjava: http://sparkjava.com/documentation.html
AdminSparkServer(int, Admin, MetricsRepository, Set<String>, boolean, Optional<SSLConfig>, boolean, Optional<DynamicAccessController>, List<ControllerRoute>, VeniceProperties, boolean, PubSubTopicRepository) - Constructor for class com.linkedin.venice.controller.server.AdminSparkServer
 
AdminTool - Class in com.linkedin.venice
 
AdminTool() - Constructor for class com.linkedin.venice.AdminTool
 
AdminTool.PrintFunction - Interface in com.linkedin.venice
 
AdminTopicMetadataAccessor - Class in com.linkedin.venice.controller
 
AdminTopicMetadataAccessor() - Constructor for class com.linkedin.venice.controller.AdminTopicMetadataAccessor
 
AdminTopicMetadataResponse - Class in com.linkedin.venice.controllerapi
 
AdminTopicMetadataResponse() - Constructor for class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
 
AdminTopicMetadataRoutes - Class in com.linkedin.venice.controller.server
 
AdminTopicMetadataRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.AdminTopicMetadataRoutes
 
AdminTopicUtils - Class in com.linkedin.venice.controller.kafka
 
AdminTopicUtils() - Constructor for class com.linkedin.venice.controller.kafka.AdminTopicUtils
 
advance(long, TimeUnit) - Static method in enum com.linkedin.alpini.base.misc.Time
 
afterHttpServerCodec(ChannelPipeline) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
AggHostHealthStats - Class in com.linkedin.venice.router.stats
 
AggHostHealthStats(MetricsRepository) - Constructor for class com.linkedin.venice.router.stats.AggHostHealthStats
 
AggHostLevelIngestionStats - Class in com.linkedin.davinci.stats
This class provides aggregate initialization support for host level ingestion stats class HostLevelIngestionStats
AggHostLevelIngestionStats(MetricsRepository, VeniceServerConfig, Map<String, StoreIngestionTask>, ReadOnlyStoreRepository, boolean, Time) - Constructor for class com.linkedin.davinci.stats.AggHostLevelIngestionStats
 
aggKafkaConsumerService - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
AggKafkaConsumerService - Class in com.linkedin.davinci.kafka.consumer
AggKafkaConsumerService supports Kafka consumer pool for multiple Kafka clusters from different data centers; for each Kafka bootstrap server url, AggKafkaConsumerService will create one KafkaConsumerService.
AggKafkaConsumerService(PubSubConsumerAdapterFactory, TopicManagerContext.PubSubPropertiesSupplier, VeniceServerConfig, EventThrottler, EventThrottler, KafkaClusterBasedRecordThrottler, MetricsRepository, TopicExistenceChecker, PubSubMessageDeserializer, Consumer<String>, Function<String, Boolean>, ReadOnlyStoreRepository) - Constructor for class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
AggKafkaConsumerServiceStats - Class in com.linkedin.davinci.stats
This class is an aggregate place that keeps stats objects for multiple stores and total stats for each region for AggKafkaConsumerService.
AggKafkaConsumerServiceStats(String, MetricsRepository, ReadOnlyStoreRepository, LongSupplier, boolean) - Constructor for class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
AggPartitionHealthStats - Class in com.linkedin.venice.controller.stats
Monitor the change of Helix's external view and warn in case that any partition is unhealthy.
AggPartitionHealthStats(String, ReadOnlyStoreRepository, PushMonitor) - Constructor for class com.linkedin.venice.controller.stats.AggPartitionHealthStats
Only for test usage.
AggPartitionHealthStats(String, MetricsRepository, RoutingDataRepository, ReadOnlyStoreRepository, PushMonitor) - Constructor for class com.linkedin.venice.controller.stats.AggPartitionHealthStats
 
AggPushHealthStats - Class in com.linkedin.venice.pushmonitor
 
AggPushHealthStats(String, MetricsRepository, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.pushmonitor.AggPushHealthStats
 
AggPushStatusCleanUpStats - Class in com.linkedin.venice.pushmonitor
 
AggPushStatusCleanUpStats(String, MetricsRepository, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.pushmonitor.AggPushStatusCleanUpStats
 
aggregate(FullHttpMessage, HttpContent) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpObjectAggregator
 
aggregate(FullHttpMessage, HttpContent) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
aggregate(O, C) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Transfers the information provided by the specified content message to the specified aggregated message.
AGGREGATE - com.linkedin.venice.meta.DataReplicationPolicy
Single Samza job or Samza job per colo pushes to real-time topic in parent colo.
AGGREGATE_REAL_TIME_SOURCE_REGION - Static variable in class com.linkedin.venice.ConfigKeys
This config defines the source region of aggregate hybrid store real-time data when native replication is enabled
aggregatedMetrics - Variable in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
A map of string key and double map value.
aggregateResponse(BASIC_HTTP_REQUEST, Metrics, List<HTTP_RESPONSE>, ResponseAggregatorFactory<BASIC_HTTP_REQUEST, HTTP_RESPONSE>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
aggregates - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The aggregates that have been computed so far since the last StartOfSegment ControlMessage.
AggRocksDBStats - Class in com.linkedin.venice.stats
Right now, Venice SN only reports aggregated metrics for RocksDB.
AggRocksDBStats(MetricsRepository, Statistics) - Constructor for class com.linkedin.venice.stats.AggRocksDBStats
 
AggRouterHttpRequestStats - Class in com.linkedin.venice.router.stats
 
AggRouterHttpRequestStats(MetricsRepository, RequestType, boolean, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
AggRouterHttpRequestStats(MetricsRepository, RequestType, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
AggServerHttpRequestStats - Class in com.linkedin.venice.stats
AggServerHttpRequestStats is the aggregate statistics for ServerHttpRequestStats corresponding to the type of requests defined in RequestType.
AggServerHttpRequestStats(MetricsRepository, RequestType, boolean, ReadOnlyStoreRepository, boolean, boolean) - Constructor for class com.linkedin.venice.stats.AggServerHttpRequestStats
 
AggServerQuotaTokenBucketStats - Class in com.linkedin.venice.stats
AggServerQuotaTokenBucketStats is the aggregate statistics for ServerQuotaTokenBucketStats.
AggServerQuotaTokenBucketStats(MetricsRepository, ReadQuotaEnforcementHandler) - Constructor for class com.linkedin.venice.stats.AggServerQuotaTokenBucketStats
 
AggServerQuotaUsageStats - Class in com.linkedin.venice.stats
AggServerQuotaUsageStats is the aggregate statistics for ServerQuotaUsageStats which measures requests and quota rejections of each store.
AggServerQuotaUsageStats(MetricsRepository) - Constructor for class com.linkedin.venice.stats.AggServerQuotaUsageStats
 
aggStats - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
AggStoreStats - Class in com.linkedin.venice.controller.stats
 
AggStoreStats(MetricsRepository, ReadOnlyStoreRepository) - Constructor for class com.linkedin.venice.controller.stats.AggStoreStats
 
AggVersionedDIVStats - Class in com.linkedin.davinci.stats
 
AggVersionedDIVStats(MetricsRepository, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.davinci.stats.AggVersionedDIVStats
 
AggVersionedIngestionStats - Class in com.linkedin.davinci.stats
The store level stats or the total stats will be unpopulated because there is no easy and reliable way to aggregate gauge stats such as rt topic offset lag.
AggVersionedIngestionStats(MetricsRepository, ReadOnlyStoreRepository, VeniceServerConfig) - Constructor for class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
AggVersionedStorageEngineStats - Class in com.linkedin.davinci.stats
 
AggVersionedStorageEngineStats(MetricsRepository, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.davinci.stats.AggVersionedStorageEngineStats
 
ALL - com.linkedin.venice.meta.VeniceUserStoreType
All user stores in Venice, excluding system stores.
ALL - Static variable in class com.linkedin.alpini.consts.Level
The ALL has the lowest possible rank and is intended to turn on all logging.
ALL_INT - Static variable in class com.linkedin.alpini.consts.Level
 
allAvroTypesExceptNullAndUnion() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
allOf(EventExecutor, Future<?>...) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
allOf(Future<?>...) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
ALLOW - com.linkedin.venice.authorization.Permission
 
ALLOW_CLUSTER_WIPE - Static variable in class com.linkedin.venice.ConfigKeys
Whether a cluster in a data center could be wiped.
ALLOW_DUPLICATE_KEY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
ALLOW_LIST_ADD_NODE - com.linkedin.venice.Command
 
ALLOW_LIST_ADD_NODE - com.linkedin.venice.controllerapi.ControllerRoute
 
ALLOW_LIST_REMOVE_NODE - com.linkedin.venice.Command
 
ALLOW_LIST_REMOVE_NODE - com.linkedin.venice.controllerapi.ControllerRoute
 
ALLOW_STORE_MIGRATION - com.linkedin.venice.Arg
 
ALLOW_STORE_MIGRATION - Static variable in class com.linkedin.venice.ConfigKeys
Whether stores are allowed to be migrated from/to a specific cluster.
ALLOW_STORE_MIGRATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
Whether stores are allowed to be migrated from/to a specific cluster.
allowFieldValueToBeNull() - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
 
allowFieldValueToBeNull() - Method in class com.linkedin.venice.compute.CountOperator
 
allowFieldValueToBeNull() - Method in class com.linkedin.venice.compute.DotProductOperator
 
allowFieldValueToBeNull() - Method in class com.linkedin.venice.compute.HadamardProductOperator
 
allowFieldValueToBeNull() - Method in interface com.linkedin.venice.compute.ReadComputeOperator
Whether the extracted value of the field in the read value record is allowed to be null.
AllowlistAccessor - Interface in com.linkedin.venice.helix
Interface defines the ways to access to the allowlist of Helix NodeId.
allPermutationGenerator(Object[]...) - Static method in class com.linkedin.venice.utils.DataProviderUtils
Generate permutations to be fed to a DataProvider.
allPermutationGenerator(Function<Object[], Boolean>, Object[]...) - Static method in class com.linkedin.venice.utils.DataProviderUtils
Generate permutations to be fed to a DataProvider.
ALREADY_CLOSED - com.linkedin.venice.utils.VeniceResourceCloseResult
 
ALWAYS_ON_MULTI_THREADED_PIPELINE - com.linkedin.venice.client.store.deserialization.BatchDeserializerType
Deprecated.
AMPLIFICATION_FACTOR - com.linkedin.venice.Arg
 
AMPLIFICATION_FACTOR - Static variable in class com.linkedin.venice.ConfigKeys
A configs of over-partitioning factor number of Kafka partitions in each partition
AMPLIFICATION_FACTOR - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
amplificationFactor - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
amplificationFactor - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
amplificationFactor - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
amplificationFactor - Variable in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
amplificationFactor - Variable in class com.linkedin.venice.metadata.response.VersionProperties
Partitioner amplification factor
amplificationFactor - Variable in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
amplificationFactor() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
amplificationFactorAdapter - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
AmplificationFactorAdapter - Class in com.linkedin.davinci.kafka.consumer
This class hides and handles amplification factor concept for each user partition.
AmplificationFactorAdapter(int, ConcurrentMap<Integer, PartitionConsumptionState>) - Constructor for class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
 
amplificationFactorAndObjectCacheConfigProvider() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
and(Predicate...) - Static method in class com.linkedin.venice.client.store.predicate.PredicateBuilder
 
AndPredicate - Class in com.linkedin.venice.client.store.predicate
 
annotateRmdSchema(Schema) - Static method in class com.linkedin.davinci.schema.SchemaUtils
Annotate all the top-level map and string array's deleted elements field of the RMD schema to use Java String as key.
annotateUpdateSchema(Schema) - Static method in class com.linkedin.davinci.schema.SchemaUtils
Annotate all the top-level map field and string array of the update schema to use Java String as key.
annotateValueSchema(Schema) - Static method in class com.linkedin.davinci.schema.SchemaUtils
Annotate all the top-level map field and string array field of the input schema to use Java String as key.
ANY_OF_ONLINE - com.linkedin.venice.meta.ReadStrategy
 
anyOf(Future<?>...) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
APACHE_HTTP_ASYNC_CLIENT - com.linkedin.venice.router.httpclient.StorageNodeClientType
Deprecated.
APACHE_KAFKA_OFFSET - Static variable in class com.linkedin.venice.pubsub.PubSubPositionType
 
ApacheHttpAsyncStorageNodeClient - Class in com.linkedin.venice.router.httpclient
 
ApacheHttpAsyncStorageNodeClient(VeniceRouterConfig, Optional<SSLFactory>, MetricsRepository, LiveInstanceMonitor) - Constructor for class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
 
ApacheKafkaAdminAdapter - Class in com.linkedin.venice.pubsub.adapter.kafka.admin
An implementation of PubSubAdminAdapter for Apache Kafka.
ApacheKafkaAdminAdapter(ApacheKafkaAdminConfig, PubSubTopicRepository) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
 
ApacheKafkaAdminAdapterFactory - Class in com.linkedin.venice.pubsub.adapter.kafka.admin
Implementation of PubSubProducerAdapterFactory used to create Apache Kafka admin clients.
ApacheKafkaAdminAdapterFactory() - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapterFactory
 
ApacheKafkaAdminConfig - Class in com.linkedin.venice.pubsub.adapter.kafka.admin
 
ApacheKafkaAdminConfig(VeniceProperties) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
 
ApacheKafkaConsumerAdapter - Class in com.linkedin.venice.pubsub.adapter.kafka.consumer
This class is not thread safe because of the internal KafkaConsumer is not thread safe.
ApacheKafkaConsumerAdapterFactory - Class in com.linkedin.venice.pubsub.adapter.kafka.consumer
 
ApacheKafkaConsumerAdapterFactory() - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapterFactory
 
ApacheKafkaConsumerConfig - Class in com.linkedin.venice.pubsub.adapter.kafka.consumer
Configuration for Apache Kafka consumer.
ApacheKafkaOffsetPosition - Class in com.linkedin.venice.pubsub.adapter.kafka
Offset position for Apache Kafka topics
ApacheKafkaOffsetPosition(long) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
ApacheKafkaOffsetPosition(ByteBuffer) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
ApacheKafkaProducerAdapter - Class in com.linkedin.venice.pubsub.adapter.kafka.producer
A wrapper over Apache Kafka producer which implements PubSubProducerAdapter
ApacheKafkaProducerAdapter(ApacheKafkaProducerConfig) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
 
ApacheKafkaProducerAdapterFactory - Class in com.linkedin.venice.pubsub.adapter.kafka.producer
Implementation of PubSubProducerAdapterFactory used to create Apache Kafka producers.
ApacheKafkaProducerAdapterFactory() - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapterFactory
 
ApacheKafkaProducerCallback - Class in com.linkedin.venice.pubsub.adapter.kafka.producer
A Kafka specific callback which wraps generic PubSubProducerCallback
ApacheKafkaProducerCallback(PubSubProducerCallback) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerCallback
 
ApacheKafkaProducerConfig - Class in com.linkedin.venice.pubsub.adapter.kafka.producer
This class holds all properties used to construct ApacheKafkaProducerAdapter (This class could be refactored to hold consumer properties as well).
ApacheKafkaProducerConfig(VeniceProperties, String, String, boolean) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
ApacheKafkaProducerConfig(Properties) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
ApacheKafkaProduceResult - Class in com.linkedin.venice.pubsub.adapter.kafka.producer
Converts RecordMetadata to PubSubProduceResult
ApacheKafkaProduceResult(RecordMetadata) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProduceResult
 
ApacheKafkaUtils - Class in com.linkedin.venice.pubsub.adapter.kafka
 
ApacheKafkaUtils() - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaUtils
 
APP_DEFAULT_LOGICAL_TS - Static variable in class com.linkedin.venice.writer.VeniceWriter
This sentinel value indicates that the venice samza apps have not provided the logical timestamp.
append(LogEvent) - Method in class com.linkedin.venice.utils.InMemoryLogAppender
 
appendCommon(StringBuilder, HttpMessage) - Static method in class com.linkedin.alpini.netty4.misc.HttpToStringUtils
 
appendError(BHS, List<HR>, HRS, String, Throwable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
appendErrorForEveryKey(BHS, List<HR>, HRS, String, Throwable, ResourcePathParser<P, K>, ScatterGatherRequest<H, K>, P) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
appendErrorsForOfflinePartitions(BHS, Scatter<H, P, K>, List<AsyncFuture<List<HR>>>) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
appendFullCommon(StringBuilder, FullHttpMessage) - Static method in class com.linkedin.alpini.netty4.misc.HttpToStringUtils
 
appendFullRequest(StringBuilder, FullHttpRequest) - Static method in class com.linkedin.alpini.netty4.misc.HttpToStringUtils
 
appendHeaders(StringBuilder, HttpHeaders) - Static method in class com.linkedin.alpini.netty4.misc.HttpToStringUtils
 
appendHex(StringBuilder, int) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
 
appendInitialLine(StringBuilder, HttpRequest) - Static method in class com.linkedin.alpini.netty4.misc.HttpToStringUtils
 
appendStackTrace(StringBuilder, Throwable) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
 
appendStackTraceElement(StringBuilder, StackTraceElement) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Appends a StackTraceElement in the same way that StackTraceElement.toString() would except without creating intermediate String objects.
appendTo(B, Iterable<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
appendTo(B, Iterator<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
appendTo(B, T...) - Method in class com.linkedin.alpini.base.misc.Joiner
 
appendTo(B, T, T, T[]) - Method in class com.linkedin.alpini.base.misc.Joiner
 
appendTo(StringBuilder, Iterable<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
appendTo(StringBuilder, Iterator<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
appendTo(StringBuilder, T...) - Method in class com.linkedin.alpini.base.misc.Joiner
 
appendTo(StringBuilder, T, T, T[]) - Method in class com.linkedin.alpini.base.misc.Joiner
 
apply() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
apply() - Method in interface com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor.TransportClientReinitProvider
 
apply(int, int) - Method in interface com.linkedin.venice.utils.BiIntFunction
 
apply(BasicFullHttpRequest) - Method in class com.linkedin.venice.router.api.VeniceMetricsProvider
 
apply(DaVinciConfig, ClientConfig, VeniceProperties, Optional<Set<String>>, ICProvider) - Method in interface com.linkedin.davinci.client.factory.CachingDaVinciClientFactory.DaVinciClientConstructor
 
apply(VenicePath) - Method in class com.linkedin.venice.router.stats.LongTailRetryStatsProvider
 
apply(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.FilterChain
This function passes the value through the filter chain to determine if the value can be filtered out or not.
apply(String) - Method in interface com.linkedin.venice.AdminTool.PrintFunction
 
apply(String, String, D2ControllerClient, int) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory.ViewClassGetter
 
apply(T, U, S) - Method in interface com.linkedin.alpini.base.misc.TriFunction
Applies this function to the given arguments.
applyAdditionalWriterConfigs(Map<String, String>) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
applyFactoryModifiers(T, List<Function<T, T>>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
applyParams(StoragePersona) - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
applyTargetVersionFilterForIncPush - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
An UpdateStore command option to enable/disable applying the target version filter for incremental pushes
applyTargetVersionFilterForIncPush - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not the target version field in Kafka messages will be used in increment push to RT policy
applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
applyToEither(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
applyToEitherAsync(CompletionStage<? extends V>, Function<? super V, U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
applyWriteCompute(GenericRecord, int, int, ByteBuffer, int, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreWriteComputeProcessor
Apply Update operation on the current value record.
AppTimeOutTrackingCompletableFuture<T> - Class in com.linkedin.venice.client.store
CompletableFuture implementation, which is able to track the timeout behavior when happening.
appWorkerChannelMaxMemorySize(long) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
appWorkerChannelMaxMemorySize(long) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
appWorkerCorePoolSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
appWorkerCorePoolSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
appWorkerKeepAliveSeconds(long) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
appWorkerKeepAliveSeconds(long) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
appWorkerTotalMaxMemorySize(long) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
appWorkerTotalMaxMemorySize(long) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
ArbitraryOrderingPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
A PollStrategy implementation which delivers messages in the order specified at construction time.
ArbitraryOrderingPollStrategy(Queue<PubSubTopicPartitionOffset>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.ArbitraryOrderingPollStrategy
 
ARCHIVED - com.linkedin.venice.pushmonitor.ExecutionStatus
Deprecated.
Arg - Enum in com.linkedin.venice
TODO: Merge this with ControllerApiConstants
argumentName() - Method in annotation type com.linkedin.alpini.cli.CLIArgument
Argument name.
array(P...) - Static method in class com.linkedin.alpini.base.misc.Pair
Return an array of Pair.
ARRAY_BLOCKING_QUEUE - com.linkedin.venice.utils.concurrent.BlockingQueueType
 
ARRAY_LIST - com.linkedin.alpini.base.monitoring.CallTrackerImpl.Mode
 
ArrayBackedNullSkippingIterator<E> - Class in com.linkedin.venice.utils.collections
This iterator traverses the entire backing array, while skipping over null entries.
ArrayBackedNullSkippingIterator(E[]) - Constructor for class com.linkedin.venice.utils.collections.ArrayBackedNullSkippingIterator
 
ArrayCollection<E> - Class in com.linkedin.venice.utils.collections
Expose an array of ArrayCollection as an immutable Collection Changes to the array are reflected in the collection.
ArrayCollection(E[]) - Constructor for class com.linkedin.venice.utils.collections.ArrayCollection
 
ArrayCollection(E[], IntSupplier) - Constructor for class com.linkedin.venice.utils.collections.ArrayCollection
 
ArrayMap<K,​V> - Class in com.linkedin.alpini.base.misc
Simple ArrayList backed Map implementation which uses simple linear scans of the list for searching for matching keys.
ArrayMap() - Constructor for class com.linkedin.alpini.base.misc.ArrayMap
 
ArrayMap(int) - Constructor for class com.linkedin.alpini.base.misc.ArrayMap
 
ArrayMap(int, BiPredicate<K, K>) - Constructor for class com.linkedin.alpini.base.misc.ArrayMap
 
ArrayMap(BiPredicate<K, K>) - Constructor for class com.linkedin.alpini.base.misc.ArrayMap
 
ArrayMap(Map<K, V>) - Constructor for class com.linkedin.alpini.base.misc.ArrayMap
 
arrayNext() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
ArraySortedSet<E> - Class in com.linkedin.alpini.base.concurrency
A thread-safe SortedSet implementation which uses an array as a backing store.
ArraySortedSet(Comparator<? super E>, int) - Constructor for class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
ArrayUtils - Class in com.linkedin.venice.utils
 
asBroadcast() - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
 
AsciiStringURLCodec - Enum in com.linkedin.alpini.netty4.misc
 
asCompletableFuture(Future<T>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
ASCTIME_DATE_FORMAT - Static variable in enum com.linkedin.alpini.base.misc.DateUtils
 
asNettyFuture(EventExecutor, CompletableFuture<T>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
asNettyFuture(CompletableFuture<T>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
asReadOnly() - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
asReadOnly() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
asScatter() - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
 
assembleAndGetValue(byte[], Iterator<byte[]>) - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler
The `valueIterator` of this function is supposed to be in descending order by offset.
assertCommand(T) - Static method in class com.linkedin.venice.utils.TestUtils
 
assertCommand(T, String) - Static method in class com.linkedin.venice.utils.TestUtils
 
assignConsumerFor(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
assignConsumerFor(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
This function assigns a consumer for the given StoreIngestionTask and returns the assigned consumer.
assignConsumerFor(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
asUnmodifiableList(float[]) - Static method in class com.linkedin.venice.utils.CollectionUtils
 
asyncDelete(long, K) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
asyncDelete(long, K) - Method in interface com.linkedin.venice.producer.VeniceProducer
A write operation to delete the record for a key.
asyncDelete(K) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
asyncDelete(K) - Method in interface com.linkedin.venice.producer.VeniceProducer
A write operation to delete the record for a key.
AsyncFullHttpRequestHandler - Class in com.linkedin.alpini.netty4.handlers
 
AsyncFullHttpRequestHandler(AsyncFullHttpRequestHandler.RequestHandler, BooleanSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
 
AsyncFullHttpRequestHandler(AsyncFullHttpRequestHandler.RequestHandler, BooleanSupplier, BooleanSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
 
AsyncFullHttpRequestHandler.RequestHandler - Interface in com.linkedin.alpini.netty4.handlers
 
AsyncFuture<T> - Interface in com.linkedin.alpini.base.concurrency
A Future which has very netty-style semantics where AsyncFutureListener can be added to the future to be executed upon condition of Success or Failure has been satisfied.
AsyncFuture.Status - Enum in com.linkedin.alpini.base.concurrency
 
AsyncFutureListener<T> - Interface in com.linkedin.alpini.base.concurrency
An interface (lambda) which is fired upon completion of an AsyncFuture.
AsyncPartitionFinder<K> - Interface in com.linkedin.alpini.router.api
Created by acurtis on 1/26/18.
AsyncPool<T> - Interface in com.linkedin.alpini.base.pool
 
AsyncPool.LifeCycle<T> - Interface in com.linkedin.alpini.base.pool
 
AsyncPoolImpl<T> - Class in com.linkedin.alpini.base.pool.impl
 
AsyncPoolImpl(AsyncPool.LifeCycle<T>, Executor, int, int, int, int, long, TimeUnit) - Constructor for class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
AsyncPoolImpl.ShutdownException - Exception in com.linkedin.alpini.base.pool.impl
 
AsyncPoolImpl.TooManyWaitersException - Exception in com.linkedin.alpini.base.pool.impl
 
AsyncPromise<T> - Interface in com.linkedin.alpini.base.concurrency
A completable AsyncFuture interface.
asyncPut(long, K, V) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
asyncPut(long, K, V) - Method in interface com.linkedin.venice.producer.VeniceProducer
A write operation where a full value is written to replace the existing value.
asyncPut(K, V) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
asyncPut(K, V) - Method in interface com.linkedin.venice.producer.VeniceProducer
A write operation where a full value is written to replace the existing value.
AsyncQOSPool<T> - Interface in com.linkedin.alpini.base.pool
 
AsyncQOSPoolImpl<T> - Class in com.linkedin.alpini.base.pool.impl
 
AsyncQOSPoolImpl(AsyncPool.LifeCycle<T>, QOSPolicy.StaticConfig, Executor, int, int, int, long, TimeUnit) - Constructor for class com.linkedin.alpini.base.pool.impl.AsyncQOSPoolImpl
 
asyncSendControlMessage(ControlMessage, int, Map<String, String>, PubSubProducerCallback, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
This API should be only used in Leader/Standby model for store ingestion.
asyncUpdate(long, K, Consumer<UpdateBuilder>) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
asyncUpdate(long, K, Consumer<UpdateBuilder>) - Method in interface com.linkedin.venice.producer.VeniceProducer
A write operation to modify a subset of fields in the record for a key.
asyncUpdate(K, Consumer<UpdateBuilder>) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
asyncUpdate(K, Consumer<UpdateBuilder>) - Method in interface com.linkedin.venice.producer.VeniceProducer
A write operation to modify a subset of fields in the record for a key.
attr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
Get the Attribute for the given AttributeKey.
attr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Get the Attribute for the given AttributeKey.
attr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpResponse
Get the Attribute for the given AttributeKey.
attr(AttributeKey<T>, T) - Method in class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
Allow to specify an initial attribute of the newly created Http2StreamChannel.
AuditInfo - Class in com.linkedin.venice.controller
 
AuditInfo(Request) - Constructor for class com.linkedin.venice.controller.AuditInfo
 
AuthorizerService - Interface in com.linkedin.venice.authorization
An interface to provide functionality to manage ACL's for a Resource and provide access permission Permission to principals Principal when performing Method.
AUTO_SCHEMA_REGISTER_FOR_PUSHJOB_ENABLED - com.linkedin.venice.Arg
 
AUTO_SCHEMA_REGISTER_FOR_PUSHJOB_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
AutoCloseableLock - Class in com.linkedin.venice.utils.locks
Concrete implementations are expected to lock their inner lock(s) in their own constructor.
AutoCloseableLock() - Constructor for class com.linkedin.venice.utils.locks.AutoCloseableLock
 
AutoCloseableMultiLock - Class in com.linkedin.venice.utils.locks
 
AutoCloseableSingleLock - Class in com.linkedin.venice.utils.locks
 
AUTOCREATE_DATA_PATH - Static variable in class com.linkedin.venice.ConfigKeys
 
available() - Method in class com.linkedin.alpini.io.ZeroInputStream
 
availableSchemaIds - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
avgAndMax() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
avgAndTotal() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
AVRO_1_4 - com.linkedin.venice.controller.kafka.protocol.enums.SchemaType
 
AVRO_BINARY - Static variable in class com.linkedin.venice.HttpConstants
 
AvroBlackHoleResponseStoreClientImpl<K,​V> - Class in com.linkedin.venice.client.store
This class should be used for experiments only.
AvroBlackHoleResponseStoreClientImpl(TransportClient, ClientConfig) - Constructor for class com.linkedin.venice.client.store.AvroBlackHoleResponseStoreClientImpl
 
AvroCollectionElementComparator - Class in com.linkedin.davinci.schema.merge
This comparator is used to compare GenericRecord collection field elements which must have schemas.
AvroCompatibilityUtils - Class in com.linkedin.venice.utils
 
AvroCompatibilityUtils() - Constructor for class com.linkedin.venice.utils.AvroCompatibilityUtils
 
AvroComputeRequestBuilderV3<K> - Class in com.linkedin.venice.client.store
This class is used to build a ComputeRequestWrapper object according to the specification, and this class will invoke AbstractAvroStoreClient to send the 'compute' request to backend.
AvroComputeRequestBuilderV3(AvroGenericReadComputeStoreClient, Schema) - Constructor for class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
 
AvroComputeRequestBuilderV4<K> - Class in com.linkedin.venice.client.store
 
AvroComputeRequestBuilderV4(AvroGenericReadComputeStoreClient, Schema) - Constructor for class com.linkedin.venice.client.store.AvroComputeRequestBuilderV4
 
avroElementComparator - Variable in class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
AvroGenericDaVinciClient<K,​V> - Class in com.linkedin.davinci.client
 
AvroGenericDaVinciClient(DaVinciConfig, ClientConfig, VeniceProperties, Optional<Set<String>>) - Constructor for class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
AvroGenericDaVinciClient(DaVinciConfig, ClientConfig, VeniceProperties, Optional<Set<String>>, ICProvider) - Constructor for class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
AvroGenericDaVinciClient(DaVinciConfig, ClientConfig, VeniceProperties, Optional<Set<String>>, ICProvider, AbstractAvroChunkingAdapter<V>, Runnable) - Constructor for class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
AvroGenericDeserializer<V> - Class in com.linkedin.venice.serializer
 
AvroGenericDeserializer(DatumReader<V>) - Constructor for class com.linkedin.venice.serializer.AvroGenericDeserializer
 
AvroGenericDeserializer(Schema, Schema) - Constructor for class com.linkedin.venice.serializer.AvroGenericDeserializer
 
AvroGenericDeserializer.IterableImpl - Enum in com.linkedin.venice.serializer
Deprecated.
AvroGenericReadComputeStoreClient<K,​V> - Interface in com.linkedin.venice.client.store
Venice avro generic client to provide read compute operations
AvroGenericStoreClient<K,​V> - Interface in com.linkedin.venice.client.store
Venice avro generic client to communicate with Venice backend for key-value lookup.
AvroGenericStoreClientImpl<K,​V> - Class in com.linkedin.venice.client.store
AvroGenericStoreClient implementation for Avro generic type.
AvroGenericStoreClientImpl(TransportClient, boolean, ClientConfig) - Constructor for class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
 
AvroGenericStoreClientImpl(TransportClient, ClientConfig) - Constructor for class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
 
AvroProtocolDefinition - Enum in com.linkedin.venice.serialization.avro
This enum lays out the basic specs of the various stateful protocols used in Venice.
AvroRecordUtils - Class in com.linkedin.venice.utils
 
AvroSchemaParseUtils - Class in com.linkedin.venice.schema
 
AvroSchemaUtils - Class in com.linkedin.venice.utils
 
AvroSerializer<K> - Class in com.linkedin.venice.serializer
AvroSerializer provides the functionality to serialize objects by using Avro.
AvroSerializer(DatumWriter<K>, DatumWriter<K>) - Constructor for class com.linkedin.venice.serializer.AvroSerializer
 
AvroSerializer(DatumWriter<K>, DatumWriter<K>, boolean) - Constructor for class com.linkedin.venice.serializer.AvroSerializer
 
AvroSerializer(Schema) - Constructor for class com.linkedin.venice.serializer.AvroSerializer
 
AvroSerializer(Schema, boolean) - Constructor for class com.linkedin.venice.serializer.AvroSerializer
 
AvroSpecificDaVinciClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.davinci.client
 
AvroSpecificDaVinciClient(DaVinciConfig, ClientConfig, VeniceProperties, Optional<Set<String>>, ICProvider) - Constructor for class com.linkedin.davinci.client.AvroSpecificDaVinciClient
 
AvroSpecificDeserializer<T extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.serializer
 
AvroSpecificDeserializer(DatumReader<T>) - Constructor for class com.linkedin.venice.serializer.AvroSpecificDeserializer
 
AvroSpecificDeserializer(Schema, Class<T>) - Constructor for class com.linkedin.venice.serializer.AvroSpecificDeserializer
 
AvroSpecificStoreClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Interface in com.linkedin.venice.client.store
AvroSpecificStoreClient for type safety purpose.
AvroSpecificStoreClientImpl<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.client.store
AvroSpecificStoreClient implementation for Avro SpecificRecord.
AvroSpecificStoreClientImpl(TransportClient, ClientConfig) - Constructor for class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
 
AvroSpecificStoreDeserializerCache<V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.serialization.avro
 
AvroSpecificStoreDeserializerCache(ReadOnlySchemaRepository, String, Class<V>) - Constructor for class com.linkedin.venice.serialization.avro.AvroSpecificStoreDeserializerCache
 
AvroSpecificStoreDeserializerCache(SchemaReader, Class<V>) - Constructor for class com.linkedin.venice.serialization.avro.AvroSpecificStoreDeserializerCache
 
AvroStoreDeserializerCache<T> - Class in com.linkedin.venice.serialization
Container for the deserializers of a single store.
AvroStoreDeserializerCache(ReadOnlySchemaRepository, String, boolean) - Constructor for class com.linkedin.venice.serialization.AvroStoreDeserializerCache
 
AvroStoreDeserializerCache(SchemaReader) - Constructor for class com.linkedin.venice.serialization.AvroStoreDeserializerCache
 
AvroSupersetSchemaUtils - Class in com.linkedin.venice.utils
 
await() - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Waits for this future to be completed.
await() - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
await() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
await() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Waits for this future to be completed.
await() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Waits for this future to be completed.
await() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
await() - Method in class com.linkedin.alpini.io.CompressOutputStream
 
await() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
await() - Method in class io.netty.bootstrap.PendingConnectPromise
 
await(long) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
await(long, TimeUnit) - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Waits for this future to be completed within the specified time limit.
await(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
await(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
await(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Waits for this future to be completed within the specified time limit.
await(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Waits for this future to be completed within the specified time limit.
await(long, TimeUnit) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
await(long, TimeUnit) - Method in interface com.linkedin.alpini.base.misc.Time.Awaitable
 
await(long, TimeUnit) - Method in class com.linkedin.alpini.io.CompressOutputStream
 
await(Time.Awaitable, long, TimeUnit) - Static method in enum com.linkedin.alpini.base.misc.Time
 
await(CountDownLatch, long, TimeUnit) - Static method in enum com.linkedin.alpini.base.misc.Time
 
await(Condition, long, TimeUnit) - Static method in enum com.linkedin.alpini.base.misc.Time
 
awaitTermination(int, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
awaitTermination(long, TimeUnit) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
awaitTermination(long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
awaitTermination(long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
awaitTermination(long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
awaitUninterruptibly() - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Waits for this future to be completed without interruption.
awaitUninterruptibly() - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
awaitUninterruptibly() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
awaitUninterruptibly() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Waits for this future to be completed without interruption.
awaitUninterruptibly() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Waits for this future to be completed without interruption.
awaitUninterruptibly() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
awaitUninterruptibly() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
awaitUninterruptibly() - Method in class io.netty.bootstrap.PendingConnectPromise
 
awaitUninterruptibly(long) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
awaitUninterruptibly(long, TimeUnit) - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Waits for this future to be completed within the specified time limit without interruption.
awaitUninterruptibly(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
awaitUninterruptibly(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
awaitUninterruptibly(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Waits for this future to be completed within the specified time limit without interruption.
awaitUninterruptibly(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Waits for this future to be completed within the specified time limit without interruption.
awaitUninterruptibly(long, TimeUnit) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 

B

b2c(byte) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
B64_FORMAT - Static variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
B64_FORMAT - Static variable in class com.linkedin.venice.RequestConstants
 
backendConfig - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
BACKFILL_SYSTEM_STORES - com.linkedin.venice.Command
 
BackgroundChannelHandler - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 5/4/17.
BackgroundChannelHandler(ChannelHandler...) - Constructor for class com.linkedin.alpini.netty4.handlers.BackgroundChannelHandler
 
BackgroundChannelHandler(Supplier<ChannelHandler[]>) - Constructor for class com.linkedin.alpini.netty4.handlers.BackgroundChannelHandler
 
BACKUP_FOLDER - com.linkedin.venice.Arg
 
BACKUP_STORE_METADATA_FROM_GRAVEYARD - com.linkedin.venice.Command
 
BACKUP_STRATEGY - com.linkedin.venice.Arg
 
BACKUP_STRATEGY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
BACKUP_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
BACKUP_VERSION_RETENTION_DAY - com.linkedin.venice.Arg
 
BACKUP_VERSION_RETENTION_MS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
backupStoreGraveyard(ZkClient, List<String>, String) - Static method in class com.linkedin.venice.RecoverStoreMetadata
 
backupStrategy - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Strategies to store backup versions.
backupStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
backupStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Strategies to store backup versions, and default is 'DELETE_ON_NEW_PUSH_START'
BackupStrategy - Enum in com.linkedin.venice.meta
Enums of the strategies used to backup older store versions in Venice.
BackupVersionOptimizationService - Class in com.linkedin.venice.cleaner
This class is used to periodically scan inactive store versions and perform optimization if the inactive period of some store version meets the pre-configured threshold, this class will trigger the database reopen action to unload unnecessary RAM usage, which was built up when there were active reads coming.
BackupVersionOptimizationService(ReadOnlyStoreRepository, StorageEngineRepository, long, long, BackupVersionOptimizationServiceStats) - Constructor for class com.linkedin.venice.cleaner.BackupVersionOptimizationService
Allocate and initialize a new BackupVersionOptimizationService object.
BackupVersionOptimizationServiceStats - Class in com.linkedin.venice.stats
BackupVersionOptimizationServiceStats record the statistics for the database optimization done by the BackupVersionOptimizationService including both successes and failures.
BackupVersionOptimizationServiceStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.BackupVersionOptimizationServiceStats
 
backupVersionRetentionMs - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Backup version retention time after a new version is promoted to the current version, if not specified, Venice will use the configured retention as the default policy
backupVersionRetentionMs - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Backup retention time, and if it is not set (-1), Venice Controller will use the default configured retention.
BACKWARD - com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
Clients using the new schema should be able to read data written with the old schema.
BAD_MESSAGE - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
BAD_REQUEST - com.linkedin.venice.exceptions.ErrorType
 
BAD_REQUEST - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
BAD_REQUEST - Static variable in class com.linkedin.venice.grpc.GrpcErrorCodes
 
BadHttpRequest - Interface in com.linkedin.alpini.netty4.misc
Created by acurtis on 9/28/17.
badRequest() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
badRequest() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
base64Decode(byte[]) - Static method in class com.linkedin.venice.utils.EncodingUtils
 
base64DecodeFromString(String) - Static method in class com.linkedin.venice.utils.EncodingUtils
 
base64Encode(byte[]) - Static method in class com.linkedin.venice.utils.EncodingUtils
 
base64Encoded() - Method in class com.linkedin.venice.router.api.RouterKey
 
base64EncodeToString(byte[]) - Static method in class com.linkedin.venice.utils.EncodingUtils
 
base64EncodeToString(ByteBuffer) - Static method in class com.linkedin.venice.utils.EncodingUtils
 
BasicClientStats - Class in com.linkedin.venice.client.stats
This class offers very basic metrics for client, and right now, it is directly used by DaVinci.
BasicClientStats(MetricsRepository, String, RequestType) - Constructor for class com.linkedin.venice.client.stats.BasicClientStats
 
BasicConsumerStats - Class in com.linkedin.davinci.consumer.stats
 
BasicConsumerStats(MetricsRepository, String) - Constructor for class com.linkedin.davinci.consumer.stats.BasicConsumerStats
 
BasicDnsResolver - Class in com.linkedin.alpini.netty4.pool
A simple asynchronous resolver which uses the default JVM blocking resolver.
BasicDnsResolver() - Constructor for class com.linkedin.alpini.netty4.pool.BasicDnsResolver
 
BasicFullHttpMultiPart - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/22/17.
BasicFullHttpMultiPart() - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(ByteBuf) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(ByteBuf, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(ByteBuf, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(ByteBuf, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(HttpMessage) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(HttpMessage, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(HttpMessage, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(HttpMessage, ByteBuf) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(HttpMessage, ByteBuf, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(HttpMessage, ByteBuf, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(HttpMessage, ByteBuf, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPart(AttributeMap, ByteBuf, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
BasicFullHttpMultiPartRequest - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/27/17.
BasicFullHttpMultiPartRequest(HttpVersion, HttpMethod, String, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
BasicFullHttpMultiPartRequest(HttpVersion, HttpMethod, String, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
BasicFullHttpMultiPartRequest(HttpVersion, HttpMethod, String, Collection<FullHttpMultiPart>, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
BasicFullHttpMultiPartRequest(HttpVersion, HttpMethod, String, Collection<FullHttpMultiPart>, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
BasicFullHttpMultiPartRequest(HttpVersion, HttpMethod, String, Collection<FullHttpMultiPart>, HttpHeaders, HttpHeaders, UUID, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
BasicFullHttpRequest - Class in com.linkedin.alpini.netty4.misc
 
BasicFullHttpRequest(FullHttpRequest) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
BasicFullHttpRequest(HttpRequest, HttpHeaders, HttpHeaders, ByteBuf) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
BasicFullHttpRequest(HttpVersion, HttpMethod, String, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
BasicFullHttpRequest(HttpVersion, HttpMethod, String, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
BasicFullHttpRequest(HttpVersion, HttpMethod, String, ByteBuf, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
BasicFullHttpRequest(HttpVersion, HttpMethod, String, ByteBuf, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
BasicFullHttpRequest(HttpVersion, HttpMethod, String, ByteBuf, HttpHeaders, HttpHeaders, UUID, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
BasicFullHttpResponse - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 4/19/17.
BasicFullHttpResponse(FullHttpResponse) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpRequest, HttpResponseStatus) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpRequest, HttpResponseStatus, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpRequest, HttpResponseStatus, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpRequest, HttpResponseStatus, ByteBuf) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpRequest, HttpResponseStatus, ByteBuf, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpRequest, HttpResponseStatus, ByteBuf, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpRequest, HttpResponseStatus, ByteBuf, HttpHeaders, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicFullHttpResponse(HttpResponse, HttpHeaders, HttpHeaders, ByteBuf) - Constructor for class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
BasicHeaders - Class in com.linkedin.alpini.netty4.misc
 
BasicHeaders(HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHeaders
 
BasicHttpClientCodec - Class in com.linkedin.alpini.netty4.handlers
A combination of HttpRequestEncoder and BasicHttpResponseDecoder which enables easier client side HTTP implementation.
BasicHttpClientCodec() - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Creates a new instance with the default decoder options (maxInitialLineLength (4096}, maxHeaderSize (8192), and maxChunkSize (8192)).
BasicHttpClientCodec(int, int, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Creates a new instance with the specified decoder options.
BasicHttpClientCodec(int, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Creates a new instance with the specified decoder options.
BasicHttpClientCodec(int, int, int, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Creates a new instance with the specified decoder options.
BasicHttpClientCodec(int, int, int, boolean, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Creates a new instance with the specified decoder options.
BasicHttpClientCodec(int, int, int, boolean, boolean, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Creates a new instance with the specified decoder options.
BasicHttpClientCodec(int, int, int, boolean, boolean, int, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Creates a new instance with the specified decoder options.
BasicHttpContentEncoder - Class in com.linkedin.alpini.netty4.handlers
A replacement for the Netty HttpContentEncoder which can handle use in client and server pipelines.
BasicHttpContentEncoder() - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
BasicHttpMultiPart - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/22/17.
BasicHttpMultiPart() - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
BasicHttpMultiPart(boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
BasicHttpMultiPart(HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
BasicHttpMultiPart(HttpMessage) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
BasicHttpMultiPart(HttpMessage, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
BasicHttpMultiPart(HttpMessage, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
BasicHttpNonMultiPartAggregator - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 3/24/17.
BasicHttpNonMultiPartAggregator(int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpNonMultiPartAggregator
 
BasicHttpNonMultiPartAggregator(int, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpNonMultiPartAggregator
 
BasicHttpObjectAggregator - Class in com.linkedin.alpini.netty4.handlers
 
BasicHttpObjectAggregator(int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpObjectAggregator
Creates a new instance.
BasicHttpObjectAggregator(int, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpObjectAggregator
Creates a new instance.
BasicHttpObjectDecoder - Class in com.linkedin.alpini.netty4.misc
 
BasicHttpObjectDecoder() - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
Creates a new instance with the default maxInitialLineLength (4096}, maxHeaderSize (8192), and maxChunkSize (8192).
BasicHttpObjectDecoder(int, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
Creates a new instance with the specified parameters.
BasicHttpObjectDecoder(int, int, int, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
Creates a new instance with the specified parameters.
BasicHttpObjectDecoder(int, int, int, boolean, boolean, int) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
BasicHttpObjectDecoder.State - Enum in com.linkedin.alpini.netty4.misc
The internal state of BasicHttpObjectDecoder.
BasicHttpRequest - Class in com.linkedin.alpini.netty4.misc
 
BasicHttpRequest(HttpRequest) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
BasicHttpRequest(HttpRequest, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
BasicHttpRequest(HttpVersion, HttpMethod, String) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Creates a new instance.
BasicHttpRequest(HttpVersion, HttpMethod, String, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Creates a new instance.
BasicHttpRequest(HttpVersion, HttpMethod, String, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Creates a new instance.
BasicHttpRequest(HttpVersion, HttpMethod, String, HttpHeaders, UUID, long, long) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Creates a new instance.
BasicHttpRequestDecoder - Class in com.linkedin.alpini.netty4.misc
 
BasicHttpRequestDecoder() - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
Creates a new instance with the default maxInitialLineLength (4096), maxHeaderSize (8192), and maxChunkSize (8192).
BasicHttpRequestDecoder(int, int, int) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
Creates a new instance with the specified parameters.
BasicHttpRequestDecoder(int, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
 
BasicHttpRequestDecoder(int, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
 
BasicHttpResponse - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/23/17.
BasicHttpResponse(HttpRequest, HttpResponseStatus) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpResponse
 
BasicHttpResponse(HttpRequest, HttpResponseStatus, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpResponse
 
BasicHttpResponse(HttpRequest, HttpResponseStatus, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpResponse
 
BasicHttpResponse(HttpRequest, HttpResponseStatus, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpResponse
 
BasicHttpResponse(HttpResponse) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpResponse
 
BasicHttpResponse(HttpResponse, HttpHeaders) - Constructor for class com.linkedin.alpini.netty4.misc.BasicHttpResponse
 
BasicHttpResponseDecoder - Class in com.linkedin.alpini.netty4.handlers
Decodes ByteBufs into HttpResponses and HttpContents.
BasicHttpResponseDecoder() - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
Creates a new instance with the default maxInitialLineLength (4096), maxHeaderSize (8192), and maxChunkSize (8192).
BasicHttpResponseDecoder(int, int, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
Creates a new instance with the specified parameters.
BasicHttpResponseDecoder(int, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
 
BasicHttpResponseDecoder(int, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
 
BasicHttpServerCodec - Class in com.linkedin.alpini.netty4.handlers
 
BasicHttpServerCodec() - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
Creates a new instance with the default decoder options (maxInitialLineLength (4096}, maxHeaderSize (8192), and maxChunkSize (8192)).
BasicHttpServerCodec(int, int, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
Creates a new instance with the specified decoder options.
BasicHttpServerCodec(int, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
Creates a new instance with the specified decoder options.
BasicHttpServerCodec(int, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
Creates a new instance with the specified decoder options.
BasicHttpServerCodec.Decoder - Class in com.linkedin.alpini.netty4.handlers
 
BasicHttpServerCodec.Encoder - Class in com.linkedin.alpini.netty4.handlers
 
BasicHttpServerCodec.ResponseOutOfSequence - Exception in com.linkedin.alpini.netty4.handlers
 
BasicRequest - Interface in com.linkedin.alpini.base.misc
 
BasicServerChannelInitializer<C extends io.netty.channel.Channel,​FACTORY extends BasicServerChannelInitializer<C,​FACTORY>> - Class in com.linkedin.alpini.netty4.handlers
 
BasicServerChannelInitializer(ConnectionLimitHandler, ActiveStreamsCountHandler, Http2SettingsFrameLogger, Timer, BooleanSupplier, AsyncFullHttpRequestHandler.RequestHandler) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
BasicServerChannelInitializer(ConnectionLimitHandler, ActiveStreamsCountHandler, Http2SettingsFrameLogger, Timer, BooleanSupplier, BooleanSupplier, AsyncFullHttpRequestHandler.RequestHandler) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
BATCH - com.linkedin.venice.meta.Version.PushType
 
BATCH_CREATE - com.linkedin.venice.authorization.Method
 
BATCH_DELETE - com.linkedin.venice.authorization.Method
 
BATCH_FOLLOWER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
BATCH_GET - com.linkedin.venice.authorization.Method
 
BATCH_GET_LIMIT - com.linkedin.venice.Arg
 
BATCH_GET_LIMIT - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
BATCH_GET_ROUTER_CACHE_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
BATCH_JOB_HEARTBEAT - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
 
BATCH_JOB_HEARTBEAT_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
BATCH_JOB_HEARTBEAT_STORE - com.linkedin.venice.common.VeniceSystemStoreType
 
BATCH_LEADER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
BATCH_NUM_BYTES_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
BATCH_ONLY - com.linkedin.venice.meta.VeniceUserStoreType
The data in batch-only stores will be populated by offline pushes/Samza reprocessing only.
BATCH_PARTIAL_UPDATE - com.linkedin.venice.authorization.Method
 
BATCH_REPLICATION_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
BATCH_UPDATE - com.linkedin.venice.authorization.Method
 
BATCH_WRITE_LOSES - com.linkedin.davinci.replication.BatchConflictResolutionPolicy
Incoming data from Batch push should always be overwritten by real-time updates.
batchConflictResolutionPolicy - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
The policy to determine timestamps of batch push records.
BatchConflictResolutionPolicy - Enum in com.linkedin.davinci.replication
 
BatchDeserializer<E,​K,​V> - Class in com.linkedin.venice.client.store.deserialization
This API controls the behavior of the user payload deserialization phase of the batch get response handling.
BatchDeserializerType - Enum in com.linkedin.venice.client.store.deserialization
This enum controls the behavior of the user payload deserialization phase of the batch get response handling.
batchGet(BatchGetRequestContext<K, V>, Set<K>) - Method in class com.linkedin.venice.fastclient.DualReadAvroGenericStoreClient
 
batchGet(BatchGetRequestContext<K, V>, Set<K>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
batchGet(VeniceClientRequest) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceBlockingStub
 
batchGet(VeniceClientRequest) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceFutureStub
 
batchGet(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.listener.grpc.VeniceReadServiceImpl
 
batchGet(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceImplBase
 
batchGet(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceStub
 
batchGet(Set<K>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
batchGet(Set<K>) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
batchGet(Set<K>) - Method in class com.linkedin.davinci.client.StatsAvroGenericDaVinciClient
 
batchGet(Set<K>) - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Get the values associated with the given keys and return them in a map of keys to values.
batchGet(Set<K>) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
batchGet(Set<K>) - Method in class com.linkedin.venice.client.store.RetriableStoreClient
Adding retry logic on router error as this method returning the completion stage value.
batchGet(Set<K>) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
batchGet(Set<K>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
BatchGetChunkingAdapter - Class in com.linkedin.davinci.storage.chunking
Batch get chunking adapter
batchGetLimit - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
The max key number allowed in batch get request, and Venice will use cluster-level config if the limit (not positive) is not valid
batchGetLimit - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
batchGetLimit - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
The max key number allowed in a batch get request
batchGetLimit - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Batch get key number limit, and Venice will use cluster-level config if it is not positive.
BatchGetRequestContext<K,​V> - Class in com.linkedin.venice.fastclient
Keep track of the progress of a batch get request .
BatchGetRequestContext(int, boolean) - Constructor for class com.linkedin.venice.fastclient.BatchGetRequestContext
 
batchGetRouterCacheEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
batchGetRouterCacheEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
BatchJobHeartbeatConfigs - Class in com.linkedin.venice.status
 
BatchJobHeartbeatKey - Class in com.linkedin.venice.status.protocol
Key part of the heartbeat sent by a push job.
BatchJobHeartbeatKey() - Constructor for class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
Default constructor.
BatchJobHeartbeatKey(CharSequence, Integer) - Constructor for class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
All-args constructor.
BatchJobHeartbeatValue - Class in com.linkedin.venice.status.protocol
Value part of the heartbeat sent by a push job
BatchJobHeartbeatValue() - Constructor for class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
Default constructor.
BatchJobHeartbeatValue(Long) - Constructor for class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
All-args constructor.
batchNumBytes - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
batchOf(int) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
batchUnsubscribe(PubSubTopic, Set<PubSubTopicPartition>) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
batchUnsubscribe(PubSubTopic, Set<PubSubTopicPartition>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
batchUnsubscribe(PubSubTopic, Set<PubSubTopicPartition>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
batchUnsubscribe(Set<PubSubTopicPartition>) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
batchUnsubscribe(Set<PubSubTopicPartition>) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Unsubscribes the consumer from a batch of topic-partitions.
batchUnsubscribe(Set<PubSubTopicPartition>) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
BDB - com.linkedin.venice.meta.PersistenceType
Persistent storage engine that writes to durable media and maintains a B+ tree in the Java heap.
beforeChunkAggregator(ChannelPipeline) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
beforeChunkAggregator(ChannelPipeline) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
beforeChunkAggregator(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
beforeChunkAggregator(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
beforeHttpRequestHandler(ChannelPipeline) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
beforeHttpRequestHandler(ChannelPipeline) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
beforeHttpRequestHandler(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
beforeHttpRequestHandler(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
beforeHttpServerCodec(ChannelPipeline) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
beforeHttpServerCodec(ChannelPipeline) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
beforeHttpServerCodec(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
beforeHttpServerCodec(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
beforeIdleStateHandler(ChannelPipeline) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
beforeIdleStateHandler(ChannelPipeline) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
beforeIdleStateHandler(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
beforeIdleStateHandler(Class<CHANNEL_PIPELINE>, Consumer<CHANNEL_PIPELINE>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
beginAggregation(HttpMessage, ByteBuf) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpObjectAggregator
 
beginAggregation(HttpMessage, ByteBuf) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
beginAggregation(HttpMessage, ByteBuf) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
beginAggregation(S, ByteBuf) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Creates a new aggregated message from the specified start message and the specified content.
beginBatchWrite(StoragePartitionConfig, Map<String, String>, Optional<Supplier<byte[]>>) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
A lot of storage engines support efficient methods for performing large number of writes (puts/deletes) against the data source.
beginBatchWrite(Map<String, String>, Optional<Supplier<byte[]>>) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
beginBatchWrite(Map<String, String>, Optional<Supplier<byte[]>>) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
beginBatchWrite(Map<String, String>, Optional<Supplier<byte[]>>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
beginEncode(HttpMessage, String) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
Prepare to encode the HTTP message content.
beginningOffset(PubSubTopicPartition, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
beginningOffset(PubSubTopicPartition, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the beginning offset for the specified PubSub topic-partition.
beginningOffset(PubSubTopicPartition, Duration) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
between(int, String, int, int) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
BiIntFunction<R> - Interface in com.linkedin.venice.utils
 
BiIntKeyCache<E> - Class in com.linkedin.venice.utils.collections
Read-through cache for items retrievable by two positive integer IDs.
BiIntKeyCache(BiIntFunction<E>) - Constructor for class com.linkedin.venice.utils.collections.BiIntKeyCache
 
BINARY - Static variable in class com.linkedin.venice.HttpConstants
 
BinaryResponse - Class in com.linkedin.venice.listener.response
 
BinaryResponse(ByteBuf) - Constructor for class com.linkedin.venice.listener.response.BinaryResponse
 
BinaryResponse(ByteBuffer) - Constructor for class com.linkedin.venice.listener.response.BinaryResponse
 
bind(ChannelHandlerContext, SocketAddress, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
bindService() - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceImplBase
 
BLACK_HOLE - com.linkedin.venice.client.store.deserialization.BatchDeserializerType
Test mode used primarily for targeted benchmarking of non-serde code paths
BLACK_HOLE - com.linkedin.venice.meta.PersistenceType
Fastest lock-free most secure of all storage engines.
BlackHoleDeserializer<E,​K,​V> - Class in com.linkedin.venice.client.store.deserialization
This BatchDeserializer does nothing, and always returns an empty list.
BlackHoleDeserializer(Executor, ClientConfig) - Constructor for class com.linkedin.venice.client.store.deserialization.BlackHoleDeserializer
 
BlackHoleStorageEngine - Class in com.linkedin.davinci.store.blackhole
 
BlackHoleStorageEngine(String) - Constructor for class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
 
BlackHoleStorageEngineFactory - Class in com.linkedin.davinci.store.blackhole
 
BlackHoleStorageEngineFactory() - Constructor for class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
BlackHoleStorageEnginePartition - Class in com.linkedin.davinci.store.blackhole
 
BlackHoleStorageEnginePartition(Integer) - Constructor for class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
BLOB_TRANSFER_ENABLED - com.linkedin.venice.Arg
 
BLOB_TRANSFER_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
blobTransferEnabled - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
blobTransferEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Flag to indicate if the blob transfer is allowed or not
blobTransferEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
blobTransferEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Flag to indicate if the blob transfer is allowed or not
blobTransferEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Flag to indicate if the blob transfer is allowed or not
block() - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
BLOCK_STRATEGY - Static variable in class com.linkedin.venice.throttle.EventThrottler
 
BLOCKING - com.linkedin.venice.client.store.deserialization.BatchDeserializerType
Only supported working mode
BLOCKING - com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl
Deprecated.
Only supported mode.
BlockingDeserializer<E,​K,​V> - Class in com.linkedin.venice.client.store.deserialization
This BatchDeserializer does not do anything asynchronously.
BlockingDeserializer(Executor, ClientConfig) - Constructor for class com.linkedin.venice.client.store.deserialization.BlockingDeserializer
 
BlockingLatch - Class in com.linkedin.alpini.base.concurrency
Created by acurtis on 10/16/17.
BlockingLatch() - Constructor for class com.linkedin.alpini.base.concurrency.BlockingLatch
 
BlockingObserverPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
This PollStrategy delegates polling to another implementation, and also executes an arbitrary function during each poll.
BlockingObserverPollStrategy(AbstractPollStrategy, Consumer<PubSubTopicPartitionOffset>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.BlockingObserverPollStrategy
 
BlockingQueueType - Enum in com.linkedin.venice.utils.concurrent
 
BOOLEAN - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
BOOLEAN - Static variable in class com.linkedin.venice.utils.DataProviderUtils
 
BOOLEAN_FALSE - Static variable in class com.linkedin.venice.utils.DataProviderUtils
 
booleanBooleanCompression() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
booleanCompression() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
bootstrap() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Returns the Bootstrap this pool will use to open new connections.
bootstrap() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Returns the Bootstrap this pool will use to open new connections.
bootstrap() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
BOOTSTRAP_TO_ONLINE_TIMEOUT_IN_HOUR - com.linkedin.venice.Arg
 
BOOTSTRAP_TO_ONLINE_TIMEOUT_IN_HOURS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
BOOTSTRAP_TO_ONLINE_TIMEOUT_IN_HOURS - Static variable in interface com.linkedin.venice.meta.Store
 
bootstrapChannel(Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
BootstrappingVeniceChangelogConsumer<K,​V> - Interface in com.linkedin.davinci.consumer
This interface is meant for users where local state must be built off of the entirety of a venice data set (i.e.
bootstrapTimeoutInMs - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
bootstrapToOnlineTimeoutInHours - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Maximum number of hours allowed for the store to transition from bootstrap to online state
bootstrapToOnlineTimeoutInHours - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
bootstrapToOnlineTimeoutInHours - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Maximum number of hours allowed for the store to transition from bootstrap to online state.
bossPoolBuilder(Class<POOL_TYPE>, Function<Executor, POOL_TYPE>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
bossPoolBuilder(Class<POOL_TYPE>, Function<Executor, POOL_TYPE>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
bossPoolSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
bossPoolSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
BOTH - com.linkedin.venice.helix.HelixViewPropertyType
 
BoundedHashMap<K,​V> - Class in com.linkedin.venice.utils
A map implementation with a bounded size.
BoundedHashMap(int, boolean) - Constructor for class com.linkedin.venice.utils.BoundedHashMap
 
BROADCAST_BY_PARTITION - Static variable in class com.linkedin.alpini.router.api.ScatterGatherMode
Sends request to every partition.
BROADCAST_BY_PRIMARY_HOST - Static variable in class com.linkedin.alpini.router.api.ScatterGatherMode
Sends request to the first host found for every partition, grouped by host.
broadcastEndOfIncrementalPush(String, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
 
broadcastEndOfPush(Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
This function might need synchronized locking.
broadcastMode(ScatterGatherMode) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
BroadcastScatterGatherRequest<H,​K> - Class in com.linkedin.alpini.router.api
This type of specialized ScatterGatherRequest does not use keys for routing, and carry some extra state.
BroadcastScatterGatherRequest(List) - Constructor for class com.linkedin.alpini.router.api.BroadcastScatterGatherRequest
 
broadcastStartOfIncrementalPush(String, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
 
broadcastStartOfPush(boolean, boolean, CompressionStrategy, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
 
broadcastStartOfPush(boolean, boolean, CompressionStrategy, Optional<ByteBuffer>, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
 
broadcastStartOfPush(boolean, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
 
broadcastStartOfPush(Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
 
broadcastTopicSwitch(List<CharSequence>, String, Long, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
 
broadcastVersionSwap(String, String, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
Broadcast control message to real-time topic partition, to be consumed by venice leader.
BUFFER_REPLAY_MINIMAL_SAFETY_MARGIN - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
BUFFER_REPLAY_POLICY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
bufferAndAssembleRecord(PubSubTopicPartition, int, byte[], ByteBuffer, long, Lazy<RecordDeserializer<T>>, int, VeniceCompressor) - Method in class com.linkedin.davinci.utils.ChunkAssembler
 
bufferReplayEnabledForHybrid - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
bufferReplayEnabledForHybrid - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Whether or not to enable buffer replay for hybrid.
bufferReplayPolicy - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Policy that will be used during buffer replay.
bufferReplayPolicy - Variable in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Policy that will be used during buffer replay.
BufferReplayPolicy - Enum in com.linkedin.venice.meta
Enums of the policies used to decide how buffer replay start timestamps are calculated.
build() - Method in class com.linkedin.alpini.base.misc.CollectionUtil.ListBuilder
 
build() - Method in class com.linkedin.alpini.base.misc.CollectionUtil.MapBuilder
 
build() - Method in class com.linkedin.alpini.base.misc.CollectionUtil.SetBuilder
 
build() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
build() - Method in interface com.linkedin.alpini.consts.config.ConfigBuilder
 
build() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
build() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
build() - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
build() - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
build() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
build() - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
build() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
build() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
build() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
build() - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
build() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig.Builder
 
build() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
build() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
build() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputScanBuilder
 
build() - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
build() - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
 
build() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
build() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
build() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
build() - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
build() - Method in class com.linkedin.venice.utils.InMemoryLogAppender.Builder
 
build() - Method in class com.linkedin.venice.utils.PropertyBuilder
 
build() - Method in class com.linkedin.venice.utils.PushInputSchemaBuilder
 
build() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
build() - Method in interface com.linkedin.venice.writer.update.UpdateBuilder
Build a GenericRecord that is ready to be sent as an Update request.
build() - Method in class com.linkedin.venice.writer.update.UpdateBuilderImpl
 
build() - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceBlockingStub
 
build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceFutureStub
 
build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceStub
 
build(Http2ConnectionDecoder, Http2ConnectionEncoder, Http2Settings) - Method in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecBuilder
 
build(SslContextBuilder) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
build(File, String, String, File, String) - Method in class com.linkedin.alpini.io.ssl.SSLContextBuilder
The keyStoreFile takes a File object of p12 or jks file depends on keyStoreType The trustStoreFile always takes a File object of JKS file.
build(String, String) - Method in class com.linkedin.alpini.io.ssl.SSLContextBuilder
Deprecated.
Builds from key store file instead of raw key store data.
buildAndSaveConfigsForForkedIngestionProcess(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
buildAndStart() - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
buildClient(String, int, int, boolean, SSLFactory) - Static method in class com.linkedin.venice.client.store.transport.HttpTransportClient
Note: The callback that is triggered by CloseableHttpAsyncClient runs in the same thread as one of it's worker threads and if the users of the future run tasks that block the release of the future thread, a deadlock will occur.
buildConfig(Properties) - Static method in class com.linkedin.venice.security.SSLConfig
Build a Config class from Properties that contains all SSL settings
buildContentType(String, String, Collection<Map.Entry<String, String>>) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
 
buildContentType(String, String, Iterator<Map.Entry<String, String>>) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
 
buildControllerClient(String, String, Optional<SSLFactory>) - Method in class com.linkedin.venice.datarecovery.Command
 
buildDictionaryOnSyntheticAvroData() - Static method in class com.linkedin.venice.compression.ZstdWithDictCompressor
Build a dictionary based on synthetic data.
builder() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
builder() - Static method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
builder() - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
builder() - Method in interface com.linkedin.alpini.router.impl.Router.PipelineFactory
 
builder() - Static method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory
 
builder() - Static method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
builder(ScatterGatherHelper<H, P, K, R, ?, ?, ?>) - Static method in interface com.linkedin.alpini.router.impl.Router
 
Builder() - Constructor for class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
Builder() - Constructor for class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
Builder() - Constructor for class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
Builder() - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
Builder() - Constructor for class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
Builder() - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
Builder() - Constructor for class com.linkedin.venice.fastclient.GrpcClientConfig.Builder
 
Builder() - Constructor for class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
Builder() - Constructor for class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
Builder() - Constructor for class com.linkedin.venice.server.VeniceServerContext.Builder
 
Builder() - Constructor for class com.linkedin.venice.utils.InMemoryLogAppender.Builder
 
Builder() - Constructor for class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
Builder(EstimateDataRecoveryTimeCommand.Params) - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
Builder(MonitorCommand.Params) - Constructor for class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
Builder(StoreRepushCommand.Params) - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
Builder(String) - Constructor for class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
Builder(String, ControllerClient, String, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
Builder(String, ControllerClient, String, Optional<SSLFactory>, LocalDateTime) - Constructor for class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
Builder(String, String, String, String, LocalDateTime, ControllerClient, String, Optional<SSLFactory>, boolean) - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
builderOf(Class<? extends Http2PipelineInitializer>) - Static method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
buildErrorResponse(BHS, HRS, String, Throwable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
buildErrorResponse(BasicFullHttpRequest, HttpResponseStatus, String, Throwable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
buildErrorResponse(HttpRequest, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
 
buildErrorResponse(HttpRequest, Throwable, HttpResponseStatus) - Method in class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
 
buildExceptionResponse(BHS, Throwable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
buildHttpResponse(HttpResponseStatus, byte[]) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
buildHttpResponse(HttpResponseStatus, ByteBuf) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
buildHttpResponse(HttpResponseStatus, String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
buildPartial() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
buildPartial() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
buildPlainTextResponse(HttpResponseStatus, ByteBuf) - Method in class com.linkedin.venice.router.api.VeniceDispatcher
 
buildQueue(QOSPolicy.StaticConfig) - Method in enum com.linkedin.alpini.base.queuing.QOSPolicy
 
buildResponse(BASIC_HTTP_REQUEST, Metrics, List<HTTP_RESPONSE>) - Method in interface com.linkedin.alpini.router.api.ResponseAggregatorFactory
 
buildResponse(BHS, Metrics, List<HR>) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
buildResponse(BasicFullHttpRequest, Metrics, List<FullHttpResponse>) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
buildResponse(BasicFullHttpRequest, Metrics, List<FullHttpResponse>) - Method in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
buildResponse(VenicePath, PortableHttpResponse) - Method in class com.linkedin.venice.router.api.VeniceDispatcher
 
buildSensorStatSummary(String, String...) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
This method is a utility method to build concise summaries useful in tests and for logging.
buildStoreViewWriters(Store, int, Schema) - Method in class com.linkedin.davinci.store.view.VeniceViewWriterFactory
 
buildTasks(Set<String>, Command.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryEstimator
 
buildTasks(Set<String>, Command.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryExecutor
 
buildTasks(Set<String>, Command.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryMonitor
 
BUILT_IN - com.linkedin.venice.meta.IngestionMode
Isolation ingestion is not enabled.
BYTE_WRAPPER - Static variable in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
Deprecated.
 
ByteArray - Class in com.linkedin.venice.utils
 
ByteArray(byte...) - Constructor for class com.linkedin.venice.utils.ByteArray
 
ByteArrayKey - Class in com.linkedin.davinci.utils
A low overhead immutable container of byte[] suitable for use as a map key.
ByteArrayKey(byte[]) - Constructor for class com.linkedin.davinci.utils.ByteArrayKey
 
byteAt(int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
ByteBufAsciiString - Class in com.linkedin.alpini.base.misc
A string implementation, similar to AsciiString, which is backed by a ByteBuf instead of a byte[] array.
ByteBufAsciiString(byte[], int, int, boolean) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
ByteBufAsciiString(ByteBufAllocator, byte[]) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
ByteBufAsciiString(ByteBufAllocator, char[]) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
Create a copy of value into this instance assuming ASCII encoding.
ByteBufAsciiString(ByteBufAllocator, char[], int, int) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
Create a copy of value into this instance assuming ASCII encoding.
ByteBufAsciiString(ByteBufAllocator, char[], Charset) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
Create a copy of value into this instance using the encoding type of charset.
ByteBufAsciiString(ByteBufAllocator, char[], Charset, int, int) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
Create a copy of value into a this instance using the encoding type of charset.
ByteBufAsciiString(ByteBufAllocator, CharSequence) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
ByteBufAsciiString(ByteBufAllocator, CharSequence, int, int) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
Create a copy of value into this instance assuming ASCII encoding.
ByteBufAsciiString(ByteBufAllocator, CharSequence, Charset) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
Create a copy of value into this instance using the encoding type of charset.
ByteBufAsciiString(ByteBufAllocator, CharSequence, Charset, int, int) - Constructor for class com.linkedin.alpini.base.misc.ByteBufAsciiString
Create a copy of value into this instance using the encoding type of charset.
ByteBufferOptimizedBinaryDecoder - Class in org.apache.avro.io
This class is a wrapper of BinaryDecoder with the following optimization: When deserializing byte array field, instead of copying the bytes into a new ByteBuffer, this class will create a ByteBuffer, which is wrapping the original array.
ByteBufferOptimizedBinaryDecoder(byte[]) - Constructor for class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
ByteBufferOptimizedBinaryDecoder(byte[], int, int) - Constructor for class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
ByteBufferToHexFormatJsonEncoder - Class in org.apache.avro.io
This class overrides JsonEncoder.writeBytes(byte[], int, int), in order to convert all bytes schema data to hexadecimal strings in the output stream, since hexadecimal strings are more readable.
ByteBufferToHexFormatJsonEncoder(Schema, OutputStream) - Constructor for class org.apache.avro.io.ByteBufferToHexFormatJsonEncoder
 
ByteBufferValueRecord<T> - Class in com.linkedin.davinci.store.record
This class encapsulates a value from venice storage accompanied by the schema id that was used to serialize the value.
ByteBufferValueRecord(T, int) - Constructor for class com.linkedin.davinci.store.record.ByteBufferValueRecord
 
BYTES - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
BYTES_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
BYTES_PER_GB - Static variable in class com.linkedin.venice.utils.ByteUtils
 
BYTES_PER_KB - Static variable in class com.linkedin.venice.utils.ByteUtils
 
BYTES_PER_MB - Static variable in class com.linkedin.venice.utils.ByteUtils
 
BytesStreamingCallback - Class in com.linkedin.davinci.callback
 
BytesStreamingCallback() - Constructor for class com.linkedin.davinci.callback.BytesStreamingCallback
 
bytesToAvro(byte[]) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
bytesToAvro(byte[], int, int) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
ByteUtils - Class in com.linkedin.venice.utils
Utility functions for munging on bytes N.B.: Most functions taken from Voldemort's ByteUtils class.
ByteUtils() - Constructor for class com.linkedin.venice.utils.ByteUtils
 

C

c - Variable in class com.linkedin.venice.serializer.SerializerDeserializerFactory.SchemaPairAndClassContainer
 
c2b(char) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
c2b0(char) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
CACHE - com.linkedin.venice.meta.PersistenceType
Similar to IN_MEMORY but with different retention rules of data (that is, data is evicted under certain circumstances)
CACHED_SQUARED_L2_NORM_KEY - Static variable in class com.linkedin.venice.compute.ComputeUtils
 
CachedDnsResolver - Class in com.linkedin.venice.httpclient
CachedDnsResolver caches the dns entries for hosts, which matches the specified host pattern.
CachedDnsResolver(String, long, DnsLookupStats) - Constructor for class com.linkedin.venice.httpclient.CachedDnsResolver
 
CachedReadOnlyStoreRepository - Class in com.linkedin.venice.helix
 
CachedReadOnlyStoreRepository(ZkClient, String, HelixAdapterSerializer, ClusterLockManager) - Constructor for class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
CachedResourceZkStateListener - Class in com.linkedin.venice.helix
Listener used to monitor zk connection state change and refresh venice resource once zk connection is reconnected.
CachedResourceZkStateListener(VeniceResource) - Constructor for class com.linkedin.venice.helix.CachedResourceZkStateListener
 
CachedResourceZkStateListener(VeniceResource, int, long) - Constructor for class com.linkedin.venice.helix.CachedResourceZkStateListener
 
cacheFastAvroGenericDeserializer(Schema, Schema, long) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
 
CachingDaVinciClientFactory - Class in com.linkedin.davinci.client.factory
 
CachingDaVinciClientFactory(D2Client, MetricsRepository, VeniceProperties) - Constructor for class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
Deprecated.
CachingDaVinciClientFactory(D2Client, MetricsRepository, VeniceProperties, Optional<Set<String>>) - Constructor for class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
Deprecated.
CachingDaVinciClientFactory(D2Client, MetricsRepository, VeniceProperties, Optional<Set<String>>, ICProvider) - Constructor for class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
Deprecated.
CachingDaVinciClientFactory(D2Client, String, MetricsRepository, VeniceProperties) - Constructor for class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
CachingDaVinciClientFactory(D2Client, String, MetricsRepository, VeniceProperties, Optional<Set<String>>) - Constructor for class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
CachingDaVinciClientFactory(D2Client, String, MetricsRepository, VeniceProperties, Optional<Set<String>>, ICProvider) - Constructor for class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
CachingDaVinciClientFactory.DaVinciClientConstructor - Interface in com.linkedin.davinci.client.factory
 
CachingVeniceStoreClientFactory - Class in com.linkedin.venice.client.factory
 
CachingVeniceStoreClientFactory(ClientConfig) - Constructor for class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
 
CachingVeniceStoreClientFactory(ClientConfig, VeniceStoreClientGlobalConfig) - Constructor for class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
 
CaffeineVeniceStoreCache - Class in com.linkedin.davinci.store.cache.caffeine
 
CaffeineVeniceStoreCache(ObjectCacheConfig, AsyncCacheLoader) - Constructor for class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
calculateDurationMs(Time, long) - Static method in class com.linkedin.venice.utils.Utils
 
calculateHashCode(F, S) - Static method in class com.linkedin.venice.utils.Pair
Deprecated.
 
calculateIdealTotalQuotaPerRouter() - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
calculateLeaderUpstreamOffsetWithTopicSwitch(PartitionConsumptionState, TopicSwitch, PubSubTopic, List<CharSequence>) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
calculateLeaderUpstreamOffsetWithTopicSwitch(PartitionConsumptionState, TopicSwitch, PubSubTopic, List<CharSequence>) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
calculateNumberOfPartitions(String, String) - Method in interface com.linkedin.venice.controller.Admin
Calculate how many partitions are needed for the given store.
calculateNumberOfPartitions(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Calculate number of partition for given store.
calculateNumberOfPartitions(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
calculatePartitionCount(String, long, int, long, int, int, boolean, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
Calculate partition count for new version.
calculateStoreQuotaPerRouter(long) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
call() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminExecutionTask
 
call(String, Callable<T>) - Method in interface com.linkedin.venice.service.ICProvider
 
call(Iterator<Row>) - Method in class com.linkedin.venice.hadoop.spark.datawriter.writer.SparkPartitionWriterFactory
 
call(Row) - Method in class com.linkedin.venice.hadoop.spark.datawriter.recordprocessor.SparkInputRecordProcessorFactory
 
callable(Runnable) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a Callable object that, when called, runs the given task and returns null.
callable(Runnable, T) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a Callable object that, when called, runs the given task and returns the given result.
callable(PrivilegedAction<?>) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a Callable object that, when called, runs the given privileged action and returns its result.
callable(PrivilegedExceptionAction<?>) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a Callable object that, when called, runs the given privileged exception action and returns its result.
Callback(TrackingStreamingCallback<K, V>) - Constructor for class com.linkedin.venice.client.store.streaming.ClientComputeRecordStreamDecoder.Callback
 
callClose(long, long) - Method in interface com.linkedin.alpini.netty4.pool.Http2PingCallListener
 
callClose(long, long) - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
callCloseWithError(long, long) - Method in interface com.linkedin.alpini.netty4.pool.Http2PingCallListener
 
callCloseWithError(long, long) - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
CallCompletion - Interface in com.linkedin.alpini.base.monitoring
 
callConstructor(Class<T>, Class<?>[], Object[]) - Static method in class com.linkedin.venice.utils.ReflectUtils
Call the class constructor with the given arguments
callStart(long, long) - Method in interface com.linkedin.alpini.netty4.pool.Http2PingCallListener
 
callStart(long, long) - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
CallTracker - Interface in com.linkedin.alpini.base.monitoring
 
CallTracker.CallStats - Interface in com.linkedin.alpini.base.monitoring
 
CallTrackerImpl - Class in com.linkedin.alpini.base.monitoring
Tracker for "load average" of a call.
CallTrackerImpl() - Constructor for class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
CallTrackerImpl(int) - Constructor for class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
CallTrackerImpl(int, ConcurrentAccumulator.Mode) - Constructor for class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
CallTrackerImpl.Mode - Enum in com.linkedin.alpini.base.monitoring
 
CAN_ALWAYS_CREATE_STREAMS - Static variable in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecBuilder
 
canAccess(Method, Resource, Principal) - Method in interface com.linkedin.venice.authorization.AuthorizerService
Check if the principal has the permission to perform the method on the resource.
canAccess(Method, Resource, Principal) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
canAccess(Method, Resource, X509Certificate) - Method in interface com.linkedin.venice.authorization.AuthorizerService
Check if the principal has the permission to perform the method on the resource.
canAccess(Method, Resource, X509Certificate) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
cancel() - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor.TimeoutFuture
Cancels a pending scheduled runnable
cancel() - Method in interface com.linkedin.alpini.router.api.RouterTimeoutProcessor.TimeoutFuture
 
cancel() - Method in class com.linkedin.venice.hadoop.VenicePushJob
A cancel method for graceful cancellation of the running Job to be invoked as a result of user actions.
cancel(boolean) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
cancel(boolean) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
cancel(boolean) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
 
cancel(boolean) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Attempts to cancel execution of this task.
cancel(boolean) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Attempts to cancel execution of this task.
cancel(boolean) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
CANCELLATION_EXCEPTION - com.linkedin.alpini.base.concurrency.AsyncFuture.Status
 
cancelled() - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Obtain an instance of an AsyncFuture which is in the Cancelled state.
CancelledAsyncFuture<T> - Class in com.linkedin.alpini.base.concurrency.impl
 
CancelledAsyncFuture() - Constructor for class com.linkedin.alpini.base.concurrency.impl.CancelledAsyncFuture
 
canCreateStream(Channel) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
canCreateStreams(Predicate<Channel>) - Method in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecBuilder
 
canDelete(VersionStatus) - Static method in enum com.linkedin.venice.meta.VersionStatus
check if a status can be deleted immediately.
canEqual(Object) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
canOpenLocalStream(Channel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Checks if the local HTTP/2 endpoint can open a new stream.
canPassThroughResponse(CompressionStrategy) - Method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
 
canRequestStorageNode(String) - Method in class com.linkedin.venice.router.api.path.VenicePath
This function is used to check whether Router could send retry request to the specified storage node.
canUseBackedArray(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
 
capabilities() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputTable
 
CAPPED_PREFIX_EXTRACTOR_LENGTH - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Length of the capped prefix extractor used with RocksDB Plain Table.
CATCH_UP_BASE_TOPIC_OFFSET_LAG - com.linkedin.venice.pushmonitor.ExecutionStatus
 
CATCH_UP_BASE_TOPIC_OFFSET_LAG - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
catching(Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
catching(Level, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
catchUpVersionTopicOffsetLag(String, int) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
catchUpVersionTopicOffsetLag(String, int) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
cause() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
cause(Throwable, Class<E>) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Return the specific cause of the given Throwable if the cause is one of the classes provided; otherwise return null.
ChainedCompletableFuture<I,​O> - Class in com.linkedin.venice.utils.concurrent
A utility class to chain two completable futures together.
ChainedCompletableFuture(CompletableFuture<I>, CompletableFuture<O>) - Constructor for class com.linkedin.venice.utils.concurrent.ChainedCompletableFuture
 
CHANGE_CAPTURE_TOPIC_SUFFIX - Static variable in class com.linkedin.venice.views.ChangeCaptureView
 
CHANGE_CAPTURE_VIEW_WRITER_CLASS_NAME - Static variable in class com.linkedin.venice.views.ChangeCaptureView
 
changeCaptureStats - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
ChangeCaptureView - Class in com.linkedin.venice.views
 
ChangeCaptureView(Properties, Store, Map<String, String>) - Constructor for class com.linkedin.venice.views.ChangeCaptureView
 
ChangeCaptureViewWriter - Class in com.linkedin.davinci.store.view
 
ChangeCaptureViewWriter(VeniceConfigLoader, Store, Schema, Map<String, String>) - Constructor for class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
 
ChangeEvent<T> - Class in com.linkedin.davinci.consumer
 
ChangeEvent(T, T) - Constructor for class com.linkedin.davinci.consumer.ChangeEvent
 
changeLiveRouterCount(int) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
changelogClientConfig - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
ChangelogClientConfig<T extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.davinci.consumer
 
ChangelogClientConfig() - Constructor for class com.linkedin.davinci.consumer.ChangelogClientConfig
 
ChangelogClientConfig(String) - Constructor for class com.linkedin.davinci.consumer.ChangelogClientConfig
 
changelogConsumer() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
channel() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
channel() - Method in class io.netty.bootstrap.PendingConnectPromise
 
CHANNEL_HANDLER_CONTEXT_ATTRIBUTE_KEY - Static variable in class com.linkedin.venice.router.streaming.VeniceChunkedWriteHandler
 
channelActive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ConnectionControlHandler
 
channelActive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
Calls ChannelHandlerContext.fireChannelActive() to forward to the next ChannelInboundHandler in the ChannelPipeline.
channelActive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
channelActive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
channelAvailableForReuse(Http2StreamChannel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Checks if a stream channel is currently available for reuse.
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ConnectionControlHandler
 
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
Calls ChannelHandlerContext.fireChannelInactive() to forward to the next ChannelInboundHandler in the ChannelPipeline.
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.HttpServerConcurrencyObserver
 
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler
 
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
channelInactive(ChannelHandlerContext) - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.codec.EspressoMessageAggregator
 
channelInactive(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
ChannelInitializer<C extends io.netty.channel.Channel> - Class in com.linkedin.alpini.netty4.handlers
A special ChannelInboundHandler which offers an easy way to initialize a Channel once it was registered to its EventLoop.
ChannelInitializer() - Constructor for class com.linkedin.alpini.netty4.handlers.ChannelInitializer
 
ChannelPoolFactory - Interface in com.linkedin.alpini.netty4.pool
An interface to construct ManagedChannelPool instances for the ChannelPoolManager.
ChannelPoolManager - Interface in com.linkedin.alpini.netty4.pool
The interface which describes the public methods of a channel pool manager.
ChannelPoolManagerImpl - Class in com.linkedin.alpini.netty4.pool
An implementation of a ChannelPoolManager.
ChannelPoolManagerImpl(E, ChannelPoolFactory, ChannelPoolResolver, int) - Constructor for class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
ChannelPoolManagerImpl(E, ChannelPoolFactory, ChannelPoolResolver, int, boolean, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
ChannelPoolManagerImpl(E, ChannelPoolFactory, ChannelPoolResolver, int, boolean, boolean, boolean, int) - Constructor for class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
ChannelPoolResolver - Interface in com.linkedin.alpini.netty4.pool
A simple interface for an asynchronous InetSocketAddress resolver.
ChannelPoolWithStats - Interface in com.linkedin.alpini.netty4.pool
A simple interface which extends ChannelPool to expose various stats.
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpNonMultiPartAggregator
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.ElideDuplicateHeadersHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.Http2PingSendHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpObjectToBasicHttpObjectAdapter
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpServerConcurrencyObserver
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpVersionFilter
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler.HttpDecodeResult
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.http2.CompactHeaderHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.venice.listener.ErrorCatchingHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.venice.listener.StatsHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.venice.listener.StorageReadRequestHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.venice.router.streaming.VeniceChunkedWriteHandler
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.EspressoMessageToMessageDecoder
 
channelRead(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
channelRead0(ChannelHandlerContext, RouterRequest) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerHandler
 
channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionReportHandler
 
channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.venice.listener.RouterRequestHttpHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerAclHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.acl.handler.StoreAclHandler
Verify if client has permission to access.
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.listener.ServerAclHandler
Verify if client has permission to access one particular resource.
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.listener.ServerStoreAclHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.listener.VerifySslHandler
If the SSL handler is not in the channel pipeline, then return 403 otherwise pass the request along the stack.
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.router.AdminOperationsHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.router.HealthCheckHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.router.MetaDataHandler
 
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.router.RouterSslVerificationHandler
If the SSL handler is not in the channel pipeline, then return 403 otherwise pass the request along the stack.
channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.router.RouterThrottleHandler
 
channelRead0(ChannelHandlerContext, Http2PingFrame) - Method in class com.linkedin.alpini.netty4.handlers.Http2PingResponseHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionReportHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.RouterRequestHttpHandler
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.codec.EspressoMessageAggregator
 
channelReadComplete(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
Notifies any child streams of the read completion.
channelRegistered(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
 
channelRegistered(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
channelRegistered(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.ServerConnectionStatsHandler
 
ChannelTaskSerializer - Class in com.linkedin.alpini.netty4.misc
The purpose of this class is to execute tasks in series without overlap, even if the ChannelTaskSerializer.executeTask(Consumer, ChannelFutureListener) method is called before the completion if the previous tasks.
ChannelTaskSerializer(ChannelHandlerContext) - Constructor for class com.linkedin.alpini.netty4.misc.ChannelTaskSerializer
 
channelUnregistered(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
channelUnregistered(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.ServerConnectionStatsHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
 
channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
charAt(int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
charAt(int) - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
CHECK_FABRIC_BUILDOUT_STATUS - com.linkedin.venice.Command
 
CHECK_RESOURCE_CLEANUP_FOR_STORE_CREATION - com.linkedin.venice.controllerapi.ControllerRoute
 
CHECK_SUM_TYPE - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
checkAllPartitionsQuota() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
Enforce partition level quota for the map.
checkAndHandleUpstreamOffsetRewind(PartitionConsumptionState, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, long, long, LeaderFollowerStoreIngestionTask) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
checkAndLogIfLagIsAcceptableForHybridStore(PartitionConsumptionState, long, long, boolean, LagType, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
Checks whether the lag is acceptable for hybrid stores
checkAndLogIfLagIsAcceptableForHybridStore(PartitionConsumptionState, long, long, boolean, LagType, long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Checks whether the lag is acceptable for hybrid stores
checkAndMaybeApplyChunkingConfigChange(VeniceParentHelixAdmin, String, String, Optional<Boolean>, UpdateStore) - Static method in class com.linkedin.venice.controller.util.ParentControllerConfigUpdateUtils
 
checkAndMaybeApplyPartialUpdateConfig(VeniceParentHelixAdmin, String, String, Optional<Boolean>, UpdateStore, boolean) - Static method in class com.linkedin.venice.controller.util.ParentControllerConfigUpdateUtils
This method takes in current status and request and try to determine whether to change partial update config.
checkAndMaybeApplyRmdChunkingConfigChange(VeniceParentHelixAdmin, String, String, Optional<Boolean>, UpdateStore) - Static method in class com.linkedin.venice.controller.util.ParentControllerConfigUpdateUtils
 
checkAndMaybeFilterValue(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.AbstractVeniceFilter
This function implements how to parse the value and determine if filtering is needed.
checkAndMaybeFilterValue(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
checkAndUpdateStatusForRemoteFabric(String, ControllerClient) - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
checkClusterSetup(HelixAdmin, String, int, int) - Static method in class com.linkedin.venice.utils.HelixUtils
Before this participant/spectator joining the Helix cluster, we need to make sure the cluster has been setup by controller.
checkComputeFieldValidity(String, String, Set<String>, ComputeOperationType) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
checkDatabaseIntegrity(int, Map<String, String>, StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
checks whether the current state of the database is valid during the start of ingestion.
checkDatabaseIntegrity(Map<String, String>) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
checks whether the current state of the database is valid during the start of ingestion.
checkDatabaseIntegrity(Map<String, String>) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
checkDatabaseIntegrity(Map<String, String>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
checkDeadLock() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
checkDeadLock() - Method in class io.netty.bootstrap.PendingConnectPromise
 
checkDisableStoreWrite(String, int) - Method in class com.linkedin.venice.meta.AbstractStore
 
checkDisableStoreWrite(String, int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
checkDisableStoreWrite(String, int) - Method in interface com.linkedin.venice.meta.Store
 
checkException(Callable<T>, String) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Utility method to catch checked exceptions from a Callable and to rethrow as a RuntimeException.
checkExecutionStatus(long) - Method in class com.linkedin.venice.controller.AdminCommandExecutionTracker
Check the latest status of execution in remote fabrics.
checkHttpVersion(HttpVersion) - Method in class com.linkedin.alpini.netty4.handlers.HttpVersionFilter
 
checkIngestionProgress(Store) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
checkInitAndQuotaEnabledToSkipQuotaEnforcement(ChannelHandlerContext, RouterRequest, Store, boolean) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
checkIsAllowListUser(Request, ControllerResponse, BooleanSupplier) - Method in class com.linkedin.venice.controller.server.VeniceRouteHandler
 
checkLastModificationTimeAndLogError(Exception, String) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
checkLastModificationTimeAndLogError(Exception, String, Reporter) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
checkLastModificationTimeAndLogError(String, Reporter) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
checkLastResponse(HttpResponse) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
 
checkLongRunningTaskState() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
The following function will be executed after processing all the quick actions in the consumer action queues, so that the long running actions doesn't block other partition's consumer actions.
checkLongRunningTaskState() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
checkMigrationStatus(CommandLine, AdminTool.PrintFunction) - Static method in class com.linkedin.venice.AdminTool
 
checkMigrationStatus(CommandLine, AdminTool.PrintFunction, ControllerClient, ControllerClient) - Static method in class com.linkedin.venice.AdminTool
 
checkMissingFieldInAvroRecord(GenericRecord, String) - Static method in class com.linkedin.venice.utils.TestUtils
 
checkMissingMessage(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, Optional<PartitionTracker.DIVErrorMetricCallback>) - Method in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
Only check for missing sequence number; segment starting from a positive sequence number is acceptable considering real-time buffer replay would start in the middle of a segment; checksum is also ignored for the same reason.
checkMissingMessage(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, Optional<PartitionTracker.DIVErrorMetricCallback>, long) - Method in class com.linkedin.davinci.validation.PartitionTracker
 
checkout(CompletableFuture<T>, CallCompletion) - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
checkOutputSpecs(FileSystem, JobConf) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictOutputFormat
 
checkPreConditionForCreateStore(String, String, String, String, boolean, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Check whether Controller should block the incoming store creation.
checkPushStatus(OfflinePushStatus, PartitionAssignment, DisableReplicaCallback) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
checkPushStatus(OfflinePushStatus, PartitionAssignment, DisableReplicaCallback) - Method in class com.linkedin.venice.pushmonitor.PartitionStatusBasedPushMonitor
Checking push status based on Venice offlinePush status
checkPushStatusAndDetailsByPartitionsStatus(OfflinePushStatus, PartitionAssignment, DisableReplicaCallback) - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
Check the current status based on PartitionStatus
checkReaderWriterCompatibility(Schema, Schema) - Static method in class com.linkedin.venice.schema.avro.SchemaCompatibility
Validates that the provided reader schema can be used to decode avro data written with the provided writer schema.
checkResourceCleanupBeforeStoreCreation(String, String) - Method in interface com.linkedin.venice.controller.Admin
Check whether there are any resource left for the store creation in cluster: {@param clusterName} If there is any, this function should throw Exception.
checkResourceCleanupBeforeStoreCreation(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
checkResourceCleanupBeforeStoreCreation(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
This function will check whether there are still resources left for the requested store in the requested cluster.
checkResourceCleanupForStoreCreation(Admin) - Method in class com.linkedin.venice.controller.server.CreateStore
 
checkResourceCleanupForStoreCreation(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
checkResultSchema(Schema, Schema, List<ComputeOperation>) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
checkSchema(Schema) - Method in class com.linkedin.venice.partitioner.InvalidKeySchemaPartitioner
 
checkSchema(Schema) - Method in class com.linkedin.venice.partitioner.VenicePartitioner
Implementors of this class can optionally provide an implementation of this function, which can perform validation of schemas to be certain that they are compatible with the partitioner implementation.
checkState(boolean) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
checkState(boolean, String) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
checkStatus() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor.HybridQuotaMonitorTask
 
checkStoreNull(ChannelHandlerContext, RouterRequest, GrpcRequestContext, boolean, Store) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
CheckSum - Class in com.linkedin.venice.kafka.validation.checksum
Parent class for various running checksum implementations.
CheckSum() - Constructor for class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
checksumState - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The value of the checksum computed since the last StartOfSegment ControlMessage.
checksumType - Variable in class com.linkedin.venice.kafka.protocol.StartOfSegment
Using int because Avro Enums are not evolvable.
checksumType - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The current mapping is the following: 0 => None, 1 => MD5, 2 => Adler32, 3 => CRC32.
CheckSumType - Enum in com.linkedin.venice.kafka.validation.checksum
Types of checksum algorithms supported by Venice's Data Ingest Validation.
checksumValue - Variable in class com.linkedin.venice.kafka.protocol.EndOfSegment
The value of the checksum computed since the last StartOfSegment ControlMessage.
checkTopicExists(String) - Method in class com.linkedin.davinci.kafka.consumer.MetadataRepoBasedTopicExistingCheckerImpl
 
checkTopicExists(String) - Method in interface com.linkedin.davinci.kafka.consumer.TopicExistenceChecker
 
checkUnwrapBoundary(Channel, String) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentCodec
 
checkUnwrapBoundary(Channel, String) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentDecoder
 
checkVersionSRTopic(String, boolean) - Static method in interface com.linkedin.venice.meta.Version
 
checkWhetherAccessHasAlreadyApproved(Metadata) - Static method in class com.linkedin.venice.listener.ServerStoreAclHandler
 
checkWhetherAccessHasAlreadyApproved(ChannelHandlerContext) - Static method in class com.linkedin.venice.listener.ServerStoreAclHandler
 
checkWhetherToStartBufferReplayForHybrid(OfflinePushStatus) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
CHILD_CLUSTER_ALLOWLIST - Static variable in class com.linkedin.venice.ConfigKeys
Only required when controller.parent.mode=true This is a comma-separated allowlist of cluster names used in the keys with the child.cluster.url prefix.
CHILD_CLUSTER_D2_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
Similar to ConfigKeys.CHILD_CLUSTER_URL_PREFIX but with D2 ZK url.
CHILD_CLUSTER_D2_SERVICE_NAME - Static variable in class com.linkedin.venice.ConfigKeys
D2 Service name for the child controllers in local datacenter
CHILD_CLUSTER_URL_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
Only required when controller.parent.mode=true This prefix specifies the location of every child cluster that is being fed by this parent cluster.
CHILD_CLUSTER_WHITELIST - Static variable in class com.linkedin.venice.ConfigKeys
Deprecated.
CHILD_CONTROLLER_ADMIN_TOPIC_CONSUMPTION_ENABLED - com.linkedin.venice.Arg
 
CHILD_CONTROLLER_ADMIN_TOPIC_CONSUMPTION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
This following config defines whether admin consumption should be enabled or not, and this config will only control the behavior in Child Controller.
CHILD_CONTROLLER_ADMIN_TOPIC_CONSUMPTION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
Whether admin consumption should be enabled.
CHILD_DATA_CENTER_KAFKA_URL_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
Config prefix for Kafka bootstrap url in all child fabrics; parent controllers need to know the Kafka url in all fabrics for native replication.
ChildAwareResponse - Class in com.linkedin.venice.controllerapi
 
ChildAwareResponse() - Constructor for class com.linkedin.venice.controllerapi.ChildAwareResponse
 
childControllerRegionD2ZkHosts - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
CHUNK - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Single chunk of a large multi-chunk value.
chunkAssembler - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
chunkAssembler - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
ChunkAssembler - Class in com.linkedin.davinci.utils
 
ChunkAssembler - Class in com.linkedin.venice.hadoop.input.kafka.chunk
This class accumulates all mapper values and assemble them to provide assembled complete large values or regular message.
ChunkAssembler(boolean) - Constructor for class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler
 
ChunkAssembler(String) - Constructor for class com.linkedin.davinci.utils.ChunkAssembler
 
ChunkAssembler.ValueBytesAndSchemaId - Class in com.linkedin.venice.hadoop.input.kafka.chunk
 
ChunkAwareCallback - Interface in com.linkedin.venice.writer
The VeniceWriter, upon detecting an instance of this class being passed to it, will always call ChunkAwareCallback.setChunkingInfo(byte[], ByteBuffer[], ChunkedValueManifest, ByteBuffer[], ChunkedValueManifest, ChunkedValueManifest, ChunkedValueManifest) whenever processing a MessageType.PUT, whether it is chunked or not.
chunked - Variable in class com.linkedin.venice.kafka.protocol.StartOfPush
Whether the messages inside the current push are encoded with chunking support.
chunked - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Whether the messages inside current store-version are encoded with chunking support.
CHUNKED_KEY_SUFFIX - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Suffix appended to the end of all keys in a store-version where chunking is enabled.
CHUNKED_VALUE_MANIFEST - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode the manifest of a multi-chunk large value.
CHUNKED_VALUE_MANIFEST_SERIALIZER - Static variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
CHUNKED_WRITE_HANDLER_ATTRIBUTE_KEY - Static variable in class com.linkedin.venice.router.streaming.VeniceChunkedWriteHandler
 
ChunkedHttpResponse - Interface in com.linkedin.alpini.netty4.misc
 
chunkedKeySuffix - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Serialized chunked key suffix and this field is not null only when this value is a chunk of a large value
ChunkedKeySuffix - Class in com.linkedin.venice.storage.protocol
This record is appended to the end of keys in a store-version where chunking is enabled.
ChunkedKeySuffix() - Constructor for class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
Default constructor.
ChunkedKeySuffix(ChunkId, Boolean) - Constructor for class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
All-args constructor.
ChunkedKeySuffixSerializer - Class in com.linkedin.venice.serialization.avro
 
ChunkedKeySuffixSerializer() - Constructor for class com.linkedin.venice.serialization.avro.ChunkedKeySuffixSerializer
 
ChunkedPayloadAndManifest - Class in com.linkedin.venice.writer
This class contains both chunked results and manifest for a specific payload.
ChunkedPayloadAndManifest(ByteBuffer[], ChunkedValueManifest) - Constructor for class com.linkedin.venice.writer.ChunkedPayloadAndManifest
 
ChunkedResponseHandler - Class in com.linkedin.alpini.netty4.handlers
 
ChunkedResponseHandler() - Constructor for class com.linkedin.alpini.netty4.handlers.ChunkedResponseHandler
 
chunkedRmdManifest - Variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
ChunkedValueInputStream - Class in com.linkedin.davinci.storage.chunking
This InputStream implementation allows us to pass a value made up of many chunks into the Avro decoder without stitching it up into a single big byte array.
ChunkedValueInputStream(int) - Constructor for class com.linkedin.davinci.storage.chunking.ChunkedValueInputStream
 
ChunkedValueManifest - Class in com.linkedin.venice.storage.protocol
This record maintains chunking information in order to re-assemble a value value that was split in many chunks.
ChunkedValueManifest() - Constructor for class com.linkedin.venice.storage.protocol.ChunkedValueManifest
Default constructor.
ChunkedValueManifest(List<ByteBuffer>, Integer, Integer) - Constructor for class com.linkedin.venice.storage.protocol.ChunkedValueManifest
All-args constructor.
ChunkedValueManifestContainer - Class in com.linkedin.davinci.storage.chunking
 
ChunkedValueManifestContainer() - Constructor for class com.linkedin.davinci.storage.chunking.ChunkedValueManifestContainer
 
ChunkedValueManifestSerializer - Class in com.linkedin.venice.serialization.avro
 
ChunkedValueManifestSerializer(boolean) - Constructor for class com.linkedin.venice.serialization.avro.ChunkedValueManifestSerializer
 
chunkId - Variable in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
This is an optional record which, if null, means that the value associated to this key does not correspond to a chunk (i.e.: it is associated to a normal non-chunked fully self-contained value, or to a ChunkedValueManifest).
ChunkId - Class in com.linkedin.venice.storage.protocol
This record contains chunking information to uniquely identify each chunk.
ChunkId() - Constructor for class com.linkedin.venice.storage.protocol.ChunkId
Default constructor.
ChunkId(GUID, Integer, Integer, Integer) - Constructor for class com.linkedin.venice.storage.protocol.ChunkId
All-args constructor.
chunkIndex - Variable in class com.linkedin.venice.storage.protocol.ChunkId
The index of the current chunk.
CHUNKING_ENABLED - com.linkedin.venice.Arg
 
CHUNKING_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
ChunkingAdapter<CHUNKS_CONTAINER,​VALUE> - Interface in com.linkedin.davinci.storage.chunking
This interface allows each code path which needs to interact with chunked values to optimize the way the re-assembly is handled so that the final form in which the is consumed is generated as efficiently as possible, via the use of a temporary ChunkingAdapter.
chunkingAndPartitionCountsCombination() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
chunkingEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
chunkingEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
chunkingEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
chunkingEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
chunkingEnabled - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
chunkingEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether current store supports large value (typically more than 1MB).
chunkingEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Whether or not large values are supported (via chunking).
ChunkingUtils - Class in com.linkedin.davinci.storage.chunking
This class and the rest of this package encapsulate the complexity of assembling chunked values from the storage engine.
ChunkingUtils() - Constructor for class com.linkedin.davinci.storage.chunking.ChunkingUtils
 
ChunkKeyValueTransformer - Interface in com.linkedin.venice.chunking
This interface provides methods to split a key into raw key/value byte array and ChunkedKeySuffix.
ChunkKeyValueTransformer.KeyType - Enum in com.linkedin.venice.chunking
 
ChunkKeyValueTransformerImpl - Class in com.linkedin.venice.chunking
 
ChunkKeyValueTransformerImpl(Schema) - Constructor for class com.linkedin.venice.chunking.ChunkKeyValueTransformerImpl
 
chunkPayloadAndSend(byte[], byte[], boolean, int, int, boolean, Supplier<String>, int, KeyWithChunkingSuffixSerializer, BiConsumer<VeniceWriter.KeyProvider, Put>) - Static method in class com.linkedin.venice.writer.WriterChunkingHelper
This method chunks payload and send each chunk out.
CIPHER_SUITE_ALLOWLIST - Static variable in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
CIPHERS - Static variable in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
ClassUtil - Class in com.linkedin.alpini.base.misc
Utilities for Classes / reflection.
cleanHeaderValue(CharSequence) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Checks to ensure that a provided header value may be used as-is or returns a new string which has been appropiately filtered.
cleanStatusMessage(CharSequence) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Cleans the status message and if no cleanup is required, returns the same String object.
CLEANUP_INSTANCE_CUSTOMIZED_STATES - com.linkedin.venice.Command
 
CLEANUP_INSTANCE_CUSTOMIZED_STATES - com.linkedin.venice.controllerapi.ControllerRoute
 
cleanupAllStores(VeniceConfigLoader) - Method in class com.linkedin.davinci.storage.StorageService
 
cleanupBackupVersion(Store, String) - Method in class com.linkedin.venice.controller.StoreBackupVersionCleanupService
Using a separate function for store cleanup is to make it easy for testing.
cleanUpHDFSPath(String, boolean) - Static method in class com.linkedin.venice.hadoop.utils.HadoopUtils
Silently clean up the given path on HDFS.
cleanupInstanceCustomizedStates() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
cleanupInstanceCustomizedStates(Admin) - Method in class com.linkedin.venice.controller.server.ClusterRoutes
Endpoint intended to be called via the admin tool manually to trigger cleanup for any lingering ZNodes produced from bugs/errors for instance level customized states.
cleanupInstanceCustomizedStates(String) - Method in interface com.linkedin.venice.controller.Admin
Scan through instance level customized states and remove any lingering ZNodes that are no longer relevant.
cleanupInstanceCustomizedStates(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
cleanupInstanceCustomizedStates(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
cleanupStoreStatus(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
cleanupStoreStatus(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Clean up all push statuses related to a store including all error pushes.
cleanupStoreStatus(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
cleanupTopicPartitionState(String, int) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
cleanupTopicPartitionState(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
cleanupTopicState(String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
cleanupTopicState(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
cleanupVeniceTopics() - Method in class com.linkedin.venice.controller.kafka.TopicCleanupServiceForParentController
 
clear() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
clear() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
clear() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
clear() - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
clear() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
clear() - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
clear() - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
TODO: we may need to rename this function to be 'close' since this resource should not used any more after calling this function.
clear() - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
 
clear() - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
clear() - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Discards all entries in the cache.
clear() - Method in class com.linkedin.davinci.utils.IndexedHashMap
Removes all of the mappings from this map.
clear() - Method in class com.linkedin.venice.controller.helix.SharedHelixReadOnlyZKSharedSchemaRepository
 
clear() - Method in class com.linkedin.venice.controller.helix.SharedHelixReadOnlyZKSharedSystemStoreRepository
 
clear() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
clear() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixExternalViewRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixLiveInstanceMonitor
 
clear() - Method in class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
Clear local cache and watches
clear() - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
clear() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
clear() - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
clear() - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
clear() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
clear() - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
clear() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
clear() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
clear() - Method in class com.linkedin.venice.pushmonitor.PushStatusCollector
 
clear() - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
clear() - Method in class com.linkedin.venice.utils.ComplementSet
 
clear() - Method in class com.linkedin.venice.utils.ConcurrentRef
 
clear() - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
 
clear() - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
clear() - Method in interface com.linkedin.venice.VeniceResource
 
CLEAR_OFFSET_RECORD - com.linkedin.venice.meta.IngestionMetadataUpdateType
 
CLEAR_STORE_VERSION_STATE - com.linkedin.venice.meta.IngestionMetadataUpdateType
 
clearAclCounter - Variable in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
clearAcls(Resource) - Method in interface com.linkedin.venice.authorization.AuthorizerService
This will clear the existing AceEntries for a resource.
clearAcls(Resource) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
clearAllOffsetState() - Method in class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
Clear all tracked offsets state
clearBitSet() - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
clearBuffer(Channel) - Static method in class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler
 
clearCachedPartitions(Version) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
clearCompressionStrategy() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 compressionStrategy = 3;
clearData() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
bytes data = 2;
clearErrorCode() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 errorCode = 6;
clearErrorMessage() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
string errorMessage = 7;
clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
clearInMemoryDB() - Method in class com.linkedin.davinci.utils.ChunkAssembler
 
clearInstanceMonitor(String) - Method in interface com.linkedin.venice.controller.Admin
 
clearInstanceMonitor(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
clearIsBatchRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isBatchRequest = 9;
clearIsRetryRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isRetryRequest = 8;
clearIsStreamingRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isStreamingRequest = 7;
clearIsStreamingResponse() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
bool isStreamingResponse = 5;
clearKeyBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for batch get
clearKeyString() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for single get
clearMethod() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string method = 10;
clearOffset(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
clearOffset(String, int) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
clearOffset(String, int) - Method in class com.linkedin.venice.offsets.DeepCopyOffsetManager
 
clearOffset(String, int) - Method in class com.linkedin.venice.offsets.InMemoryOffsetManager
 
clearOffset(String, int) - Method in interface com.linkedin.venice.offsets.OffsetManager
 
clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
clearPartition() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
uint32 partition = 1;
clearPartition(int) - Method in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
In some cases, such as when resetting offsets or unsubscribing from a partition, the PartitionTracker should forget about the state that it accumulated for a given partition.
clearPartitionOffset(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Clear the offset associated with the partitionId in the metadata partition.
clearRecord(GenericRecord) - Static method in class com.linkedin.venice.utils.AvroRecordUtils
 
clearResource(Resource) - Method in interface com.linkedin.venice.authorization.AuthorizerService
This may perform any finalization steps that may be necessary after all ACL's for a resource is deleted and the resource will not be used later.
clearResourceName() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string resourceName = 5;
clearResponseRCU() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 responseRCU = 4;
clearSchemaId() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
sint32 schemaId = 1;
clearStoreVersionState() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Clear the store version state in the metadata partition.
clearStoreVersionState(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
clearStoreVersionState(String) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
clearStoreVersionState(String) - Method in interface com.linkedin.davinci.storage.StorageMetadataService
This will clear all metadata, including store-version state and partition states, tied to {@param topicName}.
clearStoreVersionState(String) - Method in class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
This will clear all metadata, including store-version state and partition states, tied to {@param topicName}.
clearStoreVersionState(String) - Method in class com.linkedin.venice.offsets.InMemoryStorageMetadataService
 
CLIArgument - Annotation Type in com.linkedin.alpini.cli
Annotation for a command line option with an argument, like "--file ".
CLIArgumentParser<T> - Class in com.linkedin.alpini.cli
Utility class to handle typical command line argument parsing and log initialization.
CLIArgumentParser(String, Class<T>) - Constructor for class com.linkedin.alpini.cli.CLIArgumentParser
Create a new parser for the given application and argument class.
CLIENT_CERTIFICATE_ATTRIBUTE_KEY - Static variable in class com.linkedin.alpini.netty4.ssl.SecureClientHandler
 
CLIENT_CONNECTION_COUNT_GAUGE - Static variable in class com.linkedin.venice.stats.ServerConnectionStats
 
CLIENT_CONNECTION_REQUEST - Static variable in class com.linkedin.venice.stats.ServerConnectionStats
 
CLIENT_DECOMPRESSION_ENABLED - com.linkedin.venice.Arg
 
CLIENT_DECOMPRESSION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
CLIENT_PRODUCER_SCHEMA_REFRESH_INTERVAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
The refresh interval for online producer to refresh value schemas and update schemas that rely on periodic polling.
CLIENT_PRODUCER_THREAD_NUM - Static variable in class com.linkedin.venice.ConfigKeys
Number of threads for online Venice producer controlling the number of concurrent write operations.
CLIENT_SYSTEM_STORE_REPOSITORY_REFRESH_INTERVAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
The refresh interval for system store repositories that rely on periodic polling.
CLIENT_USE_DA_VINCI_BASED_SYSTEM_STORE_REPOSITORY - Static variable in class com.linkedin.venice.ConfigKeys
This config controls whether to use da-vinci based implementation of the system store repository when CLIENT_USE_SYSTEM_STORE_REPOSITORY is set to true.
CLIENT_USE_SYSTEM_STORE_REPOSITORY - Static variable in class com.linkedin.venice.ConfigKeys
A config for Da-Vinci clients to use system store based repositories or Zk based repositories.
clientCertificateValidation(ChannelHandlerContext, X509Certificate) - Method in class com.linkedin.alpini.netty4.ssl.SslClientInitializer
 
ClientComputeRecordStreamDecoder<K,​V> - Class in com.linkedin.venice.client.store.streaming
 
ClientComputeRecordStreamDecoder(List<K>, ClientComputeRecordStreamDecoder.Callback<K, V>, Executor, RecordDeserializer<StreamingFooterRecordV1>, Supplier<RecordDeserializer<V>>, Function<Integer, RecordDeserializer<V>>, BiFunction<CompressionStrategy, ByteBuffer, ByteBuffer>) - Constructor for class com.linkedin.venice.client.store.streaming.ClientComputeRecordStreamDecoder
 
ClientComputeRecordStreamDecoder.Callback<K,​V> - Class in com.linkedin.venice.client.store.streaming
 
clientConfig - Variable in class com.linkedin.davinci.repository.NativeMetadataRepository
 
clientConfig - Variable in class com.linkedin.venice.client.store.deserialization.BatchDeserializer
 
ClientConfig<T extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.client.store
 
ClientConfig<K,​V,​T extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient
 
ClientConfig() - Constructor for class com.linkedin.venice.client.store.ClientConfig
 
ClientConfig(String) - Constructor for class com.linkedin.venice.client.store.ClientConfig
 
ClientConfig.ClientConfigBuilder<K,​V,​T extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient
 
ClientConfigBuilder() - Constructor for class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
clientDecompressionEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
clientDecompressionEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
clientDecompressionEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
le/Disable client-side record decompression (default: true)
ClientFactory - Class in com.linkedin.venice.client.store
 
ClientFactory - Class in com.linkedin.venice.fastclient.factory
Every call in this factory will create its own ThinClientBasedMetadata.
ClientFactory() - Constructor for class com.linkedin.venice.client.store.ClientFactory
 
ClientFactory() - Constructor for class com.linkedin.venice.fastclient.factory.ClientFactory
 
ClientFactoryTestUtils - Class in com.linkedin.venice.client.store
 
ClientFactoryTestUtils() - Constructor for class com.linkedin.venice.client.store.ClientFactoryTestUtils
 
ClientRoutingStrategy - Interface in com.linkedin.venice.fastclient.meta
 
ClientRoutingStrategyType - Enum in com.linkedin.venice.fastclient.meta
Different routing strategy types for client side routing: 1.
ClientStats - Class in com.linkedin.venice.client.stats
 
ClientStats(MetricsRepository, String, RequestType) - Constructor for class com.linkedin.venice.client.stats.ClientStats
 
ClientTestUtils - Class in com.linkedin.venice.fastclient.utils
 
ClientTestUtils() - Constructor for class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
ClientTestUtils.FastClientHTTPVariant - Enum in com.linkedin.venice.fastclient.utils
 
CLIFlag - Annotation Type in com.linkedin.alpini.cli
Annotation for a boolean command line option without an argument, like "--exit-on-error".
CLIFooter - Annotation Type in com.linkedin.alpini.cli
Annotation for text to display as the footer of the "--help" output.
CLIHeader - Annotation Type in com.linkedin.alpini.cli
Annotation for text to display as the header of the "--help" output.
clipAndFilterNamespace(String) - Method in class com.linkedin.venice.utils.VeniceProperties
This method looks for all properties that begins with the given namespace.
CLIParser<T> - Interface in com.linkedin.alpini.cli
 
CLIUnknown - Annotation Type in com.linkedin.alpini.cli
Annotation for a String[] property which will receive all the command line elements which were not processed by the command line parser.
CLOCK - com.linkedin.davinci.store.rocksdb.RocksDBBlockCacheImplementations
ClockCache implements the CLOCK algorithm.
clone() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
clone() - Method in class com.linkedin.alpini.base.misc.TimeValue
 
clone() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.AbstractSample
 
clone() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
clone() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
clone() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
clone() - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
clone() - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
 
clone() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
clone() - Method in interface com.linkedin.venice.meta.ETLStoreConfig
 
clone() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
clone() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
clone() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
clone() - Method in interface com.linkedin.venice.meta.PartitionerConfig
 
clone() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
clone() - Method in class com.linkedin.venice.meta.ReadOnlyViewConfig
 
clone() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
clone() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
clone() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
clone() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
clone() - Method in class com.linkedin.venice.schema.SchemaEntry
 
clone() - Method in class io.netty.bootstrap.InstrumentedBootstrap
 
clone(EventLoopGroup) - Method in class io.netty.bootstrap.InstrumentedBootstrap
 
clone(EventLoopGroup) - Method in class io.netty.bootstrap.ResolveAllBootstrap
 
cloneConfig(ChangelogClientConfig<V>) - Static method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
cloneConfig(ClientConfig<V>) - Static method in class com.linkedin.venice.client.store.ClientConfig
 
cloneConfig(String, UpdateStoreQueryParams) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
cloneProducerStates(int, KafkaDataIntegrityValidator) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
We should only allow StoreIngestionTask to access StoreIngestionTask.kafkaDataIntegrityValidator; other components like leaders in LeaderFollowerStoreIngestionTask should never access the DIV validator in drainer, because messages consumption in leader is ahead of drainer, leaders and drainers are processing messages at different paces.
cloneProducerStates(int, KafkaDataIntegrityValidator) - Method in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
 
cloneProducerStates(PartitionTracker) - Method in class com.linkedin.davinci.validation.PartitionTracker
 
clonePushStatus() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
cloneRoutesClusterConfig() - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
cloneSortedSet(SortedSet<LongQuantileEstimation.Sample>) - Method in class com.linkedin.alpini.base.statistics.LongQuantileArrayEstimation
 
cloneSortedSet(SortedSet<LongQuantileEstimation.Sample>) - Method in class com.linkedin.alpini.base.statistics.LongStatsArrayAggregator
 
cloneSortedSet(SortedSet<SAMPLE>) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
cloneStore() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
cloneStore() - Method in interface com.linkedin.venice.meta.Store
 
cloneStore() - Method in class com.linkedin.venice.meta.SystemStore
 
cloneStore() - Method in class com.linkedin.venice.meta.ZKStore
Cloned a new store based on current data in this store.
cloneStoreConfig() - Method in class com.linkedin.venice.meta.StoreConfig
 
cloneUpstreamOffsetMap(Map<String, Long>) - Method in class com.linkedin.venice.offsets.OffsetRecord
Clone the checkpoint upstream offset map to another map provided as the input.
cloneVersion() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
cloneVersion() - Method in interface com.linkedin.venice.meta.Version
 
cloneVersion() - Method in class com.linkedin.venice.meta.VersionImpl
Clone a new version based on current data in this version.
ClosableHttpAsyncClientWithConnManager(CloseableHttpAsyncClient, PoolingNHttpClientConnectionManager) - Constructor for class com.linkedin.venice.httpclient.HttpClientUtils.ClosableHttpAsyncClientWithConnManager
 
close() - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
close() - Method in class com.linkedin.alpini.io.CompressOutputStream
Closes this output stream and releases any system resources associated with the stream.
close() - Method in class com.linkedin.alpini.io.PigzOutputStream
Closes this output stream and releases any system resources associated with the stream.
close() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
close() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
 
close() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
close() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
close() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
close() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
close() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
close() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
close() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
close() - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
close() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Release the internal resources.
close() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
close() - Method in class com.linkedin.davinci.DaVinciBackend
 
close() - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
close() - Method in class com.linkedin.davinci.ingestion.HttpClientTransport
 
close() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionRequestClient
 
close() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
close() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
close() - Method in class com.linkedin.davinci.kafka.consumer.ParticipantStoreConsumptionTask
 
close() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Stops the consumer task.
close() - Method in class com.linkedin.davinci.notifier.LogNotifier
 
close() - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
close() - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
The Process is shutting down and clean up the resources associated with the Notifier.
close() - Method in class com.linkedin.davinci.storage.StorageEngineRepository
 
close() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
close() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Close the specific partition
close() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
close() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
close() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
close() - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
close() - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Performs any pending maintenance operations needed by the cache.
close() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
close() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
close() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
close() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
close() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
close() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
close() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
close() - Method in class com.linkedin.davinci.store.StorageEngineFactory
Close the storage configuration
close() - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
 
close() - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
 
close() - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
 
close() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
close() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
close() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
The behavior of READ apis will be non-deterministic after `close` function is called.
close() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Release the internal resources.
close() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
close() - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
close() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
close() - Method in class com.linkedin.venice.compression.CompressorFactory
 
close() - Method in class com.linkedin.venice.compression.GzipCompressor
 
close() - Method in class com.linkedin.venice.compression.VeniceCompressor
 
close() - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
close() - Method in interface com.linkedin.venice.controller.Admin
 
close() - Method in class com.linkedin.venice.controller.authorization.SystemStoreAclSynchronizationTask
 
close() - Method in class com.linkedin.venice.controller.datarecovery.DataRecoveryManager
Cause all Venice avro client to close.
close() - Method in class com.linkedin.venice.controller.ErrorPartitionResetTask
Cause ErrorPartitionResetTask to stop executing.
close() - Method in class com.linkedin.venice.controller.helix.SharedHelixReadOnlyZKSharedSchemaRepository
 
close() - Method in class com.linkedin.venice.controller.helix.SharedHelixReadOnlyZKSharedSystemStoreRepository
 
close() - Method in interface com.linkedin.venice.controller.HelixAdminClient
Release resources.
close() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumptionTask
 
close() - Method in class com.linkedin.venice.controller.TerminalStateTopicCheckerForParentController
Causes TerminalStateTopicCheckerForParentController task to stop executing.
close() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Cause VeniceHelixAdmin and its associated services to stop executing.
close() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Cause VeniceParentHelixAdmin and its associated services to stop executing.
close() - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
close() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
close() - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
close() - Method in class com.linkedin.venice.controllerapi.D2ControllerClient
 
close() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
close() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
close() - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
close() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
 
close() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
close() - Method in class com.linkedin.venice.fastclient.meta.RetryManager
 
close() - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
close() - Method in class com.linkedin.venice.fastclient.RetriableAvroGenericStoreClient
 
close() - Method in class com.linkedin.venice.fastclient.transport.GrpcTransportClient
 
close() - Method in class com.linkedin.venice.fastclient.transport.R2TransportClient
 
close() - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
close() - Method in class com.linkedin.venice.hadoop.FilterChain
 
close() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormatCombiner
 
close() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
close() - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
close() - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
 
close() - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
close() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
 
close() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
 
close() - Method in interface com.linkedin.venice.hadoop.jobs.ComputeJob
 
close() - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
 
close() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
close() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
 
close() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
close() - Method in class com.linkedin.venice.hadoop.spark.input.VeniceAbstractPartitionReader
 
close() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
 
close() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
close() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.DuplicateKeyPrinter
 
close() - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
close() - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapperOutputReader
 
close() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
close() - Method in class com.linkedin.venice.helix.ZkAllowlistAccessor
 
close() - Method in class com.linkedin.venice.httpclient.CachedDnsResolver
 
close() - Method in class com.linkedin.venice.KafkaTopicDumper
 
close() - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
close() - Method in class com.linkedin.venice.producer.online.OnlineVeniceProducer
 
close() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
 
close() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapterFactory
 
close() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
close() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapterFactory
 
close() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapterFactory
 
close() - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Closes the PubSub consumer and releases any associated resources.
close() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
 
close() - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
close() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerRepository
 
close() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSink
 
close() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
 
close() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor.HybridQuotaMonitorTask
 
close() - Method in class com.linkedin.venice.pushmonitor.RouterBasedPushMonitor
 
close() - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
close() - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreVeniceWriterCache
 
close() - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
close() - Method in class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
 
close() - Method in class com.linkedin.venice.router.httpclient.HttpClient5StorageNodeClient
 
close() - Method in interface com.linkedin.venice.router.httpclient.StorageNodeClient
Close the client and release all resources held by the client
close() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
close() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
close() - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
Close this serializer.
close() - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
Close this serializer.
close() - Method in class com.linkedin.venice.serialization.DefaultSerializer
 
close() - Method in class com.linkedin.venice.serialization.KafkaKeySerializer
 
close() - Method in class com.linkedin.venice.serialization.StringSerializer
Close this serializer.
close() - Method in interface com.linkedin.venice.serialization.VeniceKafkaSerializer
Close this serializer.
close() - Method in class com.linkedin.venice.service.AbstractVeniceService
 
close() - Method in class com.linkedin.venice.store.StoreStateReader
 
close() - Method in class com.linkedin.venice.system.store.ControllerClientBackedSystemSchemaInitializer
 
close() - Method in class com.linkedin.venice.system.store.MetaStoreReader
 
close() - Method in class com.linkedin.venice.system.store.MetaStoreWriter
If numOfConcurrentVwCloseOps is set to -1, then all the VeniceWriters will be closed asynchronously and concurrently.
close() - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
close() - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
close() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
close() - Method in class com.linkedin.venice.utils.concurrent.CloseableThreadLocal
Clean up the resources held by this object.
close() - Method in class com.linkedin.venice.utils.locks.AutoCloseableLock
N.B.
close() - Method in class com.linkedin.venice.utils.ReferenceCounted
 
close() - Method in interface com.linkedin.venice.utils.Timer
 
close() - Method in class com.linkedin.venice.views.VeniceView
 
close() - Method in class com.linkedin.venice.writer.VeniceWriter
 
close(boolean) - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
close(boolean) - Method in class com.linkedin.venice.writer.VeniceWriter
Close the VeniceWriter
close(boolean, boolean) - Method in class com.linkedin.venice.writer.VeniceWriter
Deprecated.
close(int, boolean) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
 
close(int, boolean) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
 
close(int, boolean) - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
 
close(int, boolean) - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
 
close(long) - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
close(ChannelHandlerContext, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
close(ChannelHandlerContext, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
close(String) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
Close the connection pool to the specified host and port.
close(String) - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
close(String) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
close(String, int) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
 
close(String, int, boolean) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
 
CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
CloseableThreadLocal<T extends java.lang.AutoCloseable> - Class in com.linkedin.venice.utils.concurrent
A wrapper of ThreadLocal for AutoCloseable objects.
CloseableThreadLocal(Supplier<T>) - Constructor for class com.linkedin.venice.utils.concurrent.CloseableThreadLocal
Creates a closeable thread local.
closeAfterContinueResponse(Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Determine if the channel should be closed after the result of EspressoMessageAggregator.newContinueResponse(Object, int, ChannelPipeline) is written.
closeAfterContinueResponse(Object) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
closeAllStorageEngines() - Method in class com.linkedin.davinci.storage.StorageService
 
closeAsync() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
Closes the pool in an async manner.
closeAsync() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Closes the pool in an async manner.
closeAsync(boolean) - Method in class com.linkedin.venice.writer.VeniceWriter
 
closeAsync(boolean, boolean) - Method in class com.linkedin.venice.writer.VeniceWriter
 
closeChannel(Channel) - Static method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
closeCompletion(long, T, Throwable) - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
closeCompletion(T, Throwable) - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
closed - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
closeFuture() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
closeFuture() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
closeFuture() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
closeFuture() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
closeMetadataPartition() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
closePartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
closePartition(int) - Method in class com.linkedin.venice.writer.VeniceWriter
Close a single partition from this writer.
closeQuietly(Closeable) - Static method in enum com.linkedin.alpini.io.IOUtils
 
closeQuietly(Connection) - Static method in enum com.linkedin.alpini.base.misc.JDBCUtils
 
closeQuietly(ResultSet) - Static method in enum com.linkedin.alpini.base.misc.JDBCUtils
 
closeQuietly(Statement) - Static method in enum com.linkedin.alpini.base.misc.JDBCUtils
 
closeQuietlyWithErrorLogged(Closeable...) - Static method in class com.linkedin.venice.utils.Utils
 
closeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
closeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
closeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
closeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.StorageEngineFactory
Close the storage engine from the underlying storage configuration
closeStorageEngine(String) - Method in class com.linkedin.davinci.storage.StorageService
 
closeStorePartition(VeniceStoreVersionConfig, int) - Method in class com.linkedin.davinci.storage.StorageService
 
closeStreamChannel(Http2StreamChannel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
closeVeniceViewWriters() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
closeVeniceViewWriters() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
closeVeniceWriters(boolean) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
closeVeniceWriters(boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
closeWithError() - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
closeWithError(long) - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
closeWithError(long, Throwable) - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
closeWithError(Throwable) - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
cluster - Variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
The Venice cluster of the store.
CLUSTER - com.linkedin.venice.Arg
 
CLUSTER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
CLUSTER_DEST - com.linkedin.venice.Arg
 
CLUSTER_DEST - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
CLUSTER_DISCOVERY - com.linkedin.venice.controllerapi.ControllerRoute
 
CLUSTER_DISCOVERY_D2_SERVICE - Static variable in class com.linkedin.venice.ConfigKeys
D2 Service name for cluster discovery
ClUSTER_HEALTH_INSTANCES - com.linkedin.venice.controllerapi.ControllerRoute
 
CLUSTER_HEALTH_INSTANCES - com.linkedin.venice.Command
 
CLUSTER_HEALTH_STORES - com.linkedin.venice.Command
 
CLUSTER_HEALTH_STORES - com.linkedin.venice.controllerapi.ControllerRoute
 
CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
 
CLUSTER_PROPERTIES_FILE - Static variable in class com.linkedin.davinci.config.VeniceConfigLoader
 
CLUSTER_SRC - com.linkedin.venice.Arg
 
CLUSTER_TO_D2 - Static variable in class com.linkedin.venice.ConfigKeys
 
CLUSTER_TO_SERVER_D2 - Static variable in class com.linkedin.venice.ConfigKeys
 
clusterConfigZkPath - Variable in class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
 
ClusterDiscovery - Class in com.linkedin.venice.controller.server
 
ClusterDiscovery() - Constructor for class com.linkedin.venice.controller.server.ClusterDiscovery
 
ClusterInfoProvider - Interface in com.linkedin.venice.meta
 
ClusterLeaderInitializationManager - Class in com.linkedin.venice.controller.init
Takes care of executing each routine once per cluster.
ClusterLeaderInitializationManager(List<ClusterLeaderInitializationRoutine>, boolean) - Constructor for class com.linkedin.venice.controller.init.ClusterLeaderInitializationManager
 
ClusterLeaderInitializationRoutine - Interface in com.linkedin.venice.controller.init
This class encapsulates business logic which needs to be executed once per cluster the first time a controller becomes leader of that cluster.
clusterLockManager - Variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
ClusterLockManager - Class in com.linkedin.venice.utils.locks
A centralized place to control the locking behavior, such as lock order and lock granularity.
ClusterLockManager(String) - Constructor for class com.linkedin.venice.utils.locks.ClusterLockManager
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
clusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
clusterName - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
clusterName - Variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
clusterName - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
ClusterRoutes - Class in com.linkedin.venice.controller.server
 
ClusterRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.ClusterRoutes
 
ClusterStaleDataAuditResponse - Class in com.linkedin.venice.controllerapi
 
ClusterStaleDataAuditResponse() - Constructor for class com.linkedin.venice.controllerapi.ClusterStaleDataAuditResponse
 
ClusterStats - Class in com.linkedin.venice.fastclient.stats
This class includes the metrics in the cluster-level.
ClusterStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.fastclient.stats.ClusterStats
 
clusterStoreRepositoryPath - Variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
code - Variable in enum com.linkedin.venice.stats.StatsErrorCode
 
code() - Method in exception com.linkedin.alpini.base.misc.ExceptionWithStatus
 
collect(List<AsyncFuture<List<T>>>, boolean) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
 
COLLECTION_TS_ARRAY_SCHEMA - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
CollectionFieldOperationHandler - Class in com.linkedin.davinci.schema.merge
This class handles all operations on a collection field with replication metadata.
CollectionFieldOperationHandler(AvroCollectionElementComparator) - Constructor for class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
CollectionRmdTimestamp<DELETED_ELEMENT_TYPE> - Class in com.linkedin.venice.schema.rmd.v1
This class centralizes the logic of creating a collection replication metadata schema and providing a POJO representation upon a collection replication metadata generic record.
CollectionRmdTimestamp(CollectionRmdTimestamp) - Constructor for class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
CollectionRmdTimestamp(GenericRecord) - Constructor for class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
CollectionTimestampMergeRecordHelper - Class in com.linkedin.davinci.schema.merge
This class handles merges with replication metadata with collection metadata timestamp CollectionRmdTimestamp for collection field.
CollectionTimestampMergeRecordHelper() - Constructor for class com.linkedin.davinci.schema.merge.CollectionTimestampMergeRecordHelper
 
CollectionUtil - Enum in com.linkedin.alpini.base.misc
 
CollectionUtil.ListBuilder<T> - Class in com.linkedin.alpini.base.misc
 
CollectionUtil.MapBuilder<K,​V> - Class in com.linkedin.alpini.base.misc
 
CollectionUtil.SetBuilder<T> - Class in com.linkedin.alpini.base.misc
 
CollectionUtils - Class in com.linkedin.venice.utils
 
CollectionUtils() - Constructor for class com.linkedin.venice.utils.CollectionUtils
 
collector() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
COLLECTOR - Static variable in class com.linkedin.alpini.base.statistics.Welfords.DoubleWelford
 
COLLECTOR - Static variable in class com.linkedin.alpini.base.statistics.Welfords.LongWelford
 
coloStatus - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
columnFamilyDescriptors - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
columnFamilyHandleList - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
Column Family is the concept in RocksDB to create isolation between different value for the same key.
com.linkedin.alpini.base.concurrency - package com.linkedin.alpini.base.concurrency
 
com.linkedin.alpini.base.concurrency.impl - package com.linkedin.alpini.base.concurrency.impl
 
com.linkedin.alpini.base.hash - package com.linkedin.alpini.base.hash
 
com.linkedin.alpini.base.misc - package com.linkedin.alpini.base.misc
 
com.linkedin.alpini.base.monitoring - package com.linkedin.alpini.base.monitoring
 
com.linkedin.alpini.base.pool - package com.linkedin.alpini.base.pool
 
com.linkedin.alpini.base.pool.impl - package com.linkedin.alpini.base.pool.impl
 
com.linkedin.alpini.base.queuing - package com.linkedin.alpini.base.queuing
 
com.linkedin.alpini.base.registry - package com.linkedin.alpini.base.registry
 
com.linkedin.alpini.base.registry.impl - package com.linkedin.alpini.base.registry.impl
 
com.linkedin.alpini.base.safealloc - package com.linkedin.alpini.base.safealloc
 
com.linkedin.alpini.base.ssl - package com.linkedin.alpini.base.ssl
 
com.linkedin.alpini.base.statistics - package com.linkedin.alpini.base.statistics
 
com.linkedin.alpini.base.test - package com.linkedin.alpini.base.test
 
com.linkedin.alpini.cli - package com.linkedin.alpini.cli
 
com.linkedin.alpini.consts - package com.linkedin.alpini.consts
Package exclusively for constants and enums.
com.linkedin.alpini.consts.config - package com.linkedin.alpini.consts.config
 
com.linkedin.alpini.io - package com.linkedin.alpini.io
 
com.linkedin.alpini.io.ssl - package com.linkedin.alpini.io.ssl
 
com.linkedin.alpini.jna - package com.linkedin.alpini.jna
 
com.linkedin.alpini.log - package com.linkedin.alpini.log
 
com.linkedin.alpini.netty4.compression - package com.linkedin.alpini.netty4.compression
 
com.linkedin.alpini.netty4.handlers - package com.linkedin.alpini.netty4.handlers
 
com.linkedin.alpini.netty4.http2 - package com.linkedin.alpini.netty4.http2
 
com.linkedin.alpini.netty4.misc - package com.linkedin.alpini.netty4.misc
 
com.linkedin.alpini.netty4.pool - package com.linkedin.alpini.netty4.pool
 
com.linkedin.alpini.netty4.ssl - package com.linkedin.alpini.netty4.ssl
 
com.linkedin.alpini.router - package com.linkedin.alpini.router
 
com.linkedin.alpini.router.api - package com.linkedin.alpini.router.api
 
com.linkedin.alpini.router.impl - package com.linkedin.alpini.router.impl
 
com.linkedin.alpini.router.impl.netty4 - package com.linkedin.alpini.router.impl.netty4
 
com.linkedin.alpini.router.monitoring - package com.linkedin.alpini.router.monitoring
 
com.linkedin.avro.fastserde - package com.linkedin.avro.fastserde
 
com.linkedin.davinci - package com.linkedin.davinci
 
com.linkedin.davinci.callback - package com.linkedin.davinci.callback
 
com.linkedin.davinci.client - package com.linkedin.davinci.client
 
com.linkedin.davinci.client.factory - package com.linkedin.davinci.client.factory
 
com.linkedin.davinci.compression - package com.linkedin.davinci.compression
 
com.linkedin.davinci.config - package com.linkedin.davinci.config
 
com.linkedin.davinci.consumer - package com.linkedin.davinci.consumer
 
com.linkedin.davinci.consumer.stats - package com.linkedin.davinci.consumer.stats
 
com.linkedin.davinci.helix - package com.linkedin.davinci.helix
 
com.linkedin.davinci.ingestion - package com.linkedin.davinci.ingestion
 
com.linkedin.davinci.ingestion.consumption - package com.linkedin.davinci.ingestion.consumption
 
com.linkedin.davinci.ingestion.isolated - package com.linkedin.davinci.ingestion.isolated
 
com.linkedin.davinci.ingestion.main - package com.linkedin.davinci.ingestion.main
 
com.linkedin.davinci.ingestion.utils - package com.linkedin.davinci.ingestion.utils
 
com.linkedin.davinci.kafka.consumer - package com.linkedin.davinci.kafka.consumer
 
com.linkedin.davinci.listener.response - package com.linkedin.davinci.listener.response
 
com.linkedin.davinci.notifier - package com.linkedin.davinci.notifier
 
com.linkedin.davinci.replication - package com.linkedin.davinci.replication
 
com.linkedin.davinci.replication.merge - package com.linkedin.davinci.replication.merge
 
com.linkedin.davinci.repository - package com.linkedin.davinci.repository
 
com.linkedin.davinci.schema - package com.linkedin.davinci.schema
 
com.linkedin.davinci.schema.merge - package com.linkedin.davinci.schema.merge
 
com.linkedin.davinci.schema.writecompute - package com.linkedin.davinci.schema.writecompute
 
com.linkedin.davinci.serializer.avro - package com.linkedin.davinci.serializer.avro
 
com.linkedin.davinci.serializer.avro.fast - package com.linkedin.davinci.serializer.avro.fast
 
com.linkedin.davinci.stats - package com.linkedin.davinci.stats
 
com.linkedin.davinci.stats.ingestion.heartbeat - package com.linkedin.davinci.stats.ingestion.heartbeat
 
com.linkedin.davinci.storage - package com.linkedin.davinci.storage
 
com.linkedin.davinci.storage.chunking - package com.linkedin.davinci.storage.chunking
 
com.linkedin.davinci.store - package com.linkedin.davinci.store
 
com.linkedin.davinci.store.blackhole - package com.linkedin.davinci.store.blackhole
 
com.linkedin.davinci.store.cache - package com.linkedin.davinci.store.cache
 
com.linkedin.davinci.store.cache.backend - package com.linkedin.davinci.store.cache.backend
 
com.linkedin.davinci.store.cache.caffeine - package com.linkedin.davinci.store.cache.caffeine
 
com.linkedin.davinci.store.memory - package com.linkedin.davinci.store.memory
 
com.linkedin.davinci.store.record - package com.linkedin.davinci.store.record
 
com.linkedin.davinci.store.rocksdb - package com.linkedin.davinci.store.rocksdb
 
com.linkedin.davinci.store.view - package com.linkedin.davinci.store.view
 
com.linkedin.davinci.utils - package com.linkedin.davinci.utils
 
com.linkedin.davinci.validation - package com.linkedin.davinci.validation
 
com.linkedin.venice - package com.linkedin.venice
 
com.linkedin.venice.acl - package com.linkedin.venice.acl
 
com.linkedin.venice.acl.handler - package com.linkedin.venice.acl.handler
 
com.linkedin.venice.admin - package com.linkedin.venice.admin
 
com.linkedin.venice.admin.protocol.response - package com.linkedin.venice.admin.protocol.response
 
com.linkedin.venice.annotation - package com.linkedin.venice.annotation
 
com.linkedin.venice.authorization - package com.linkedin.venice.authorization
 
com.linkedin.venice.chunking - package com.linkedin.venice.chunking
 
com.linkedin.venice.cleaner - package com.linkedin.venice.cleaner
 
com.linkedin.venice.client - package com.linkedin.venice.client
 
com.linkedin.venice.client.change.capture.protocol - package com.linkedin.venice.client.change.capture.protocol
 
com.linkedin.venice.client.exceptions - package com.linkedin.venice.client.exceptions
 
com.linkedin.venice.client.factory - package com.linkedin.venice.client.factory
 
com.linkedin.venice.client.schema - package com.linkedin.venice.client.schema
 
com.linkedin.venice.client.stats - package com.linkedin.venice.client.stats
 
com.linkedin.venice.client.store - package com.linkedin.venice.client.store
 
com.linkedin.venice.client.store.deserialization - package com.linkedin.venice.client.store.deserialization
 
com.linkedin.venice.client.store.predicate - package com.linkedin.venice.client.store.predicate
 
com.linkedin.venice.client.store.schemas - package com.linkedin.venice.client.store.schemas
 
com.linkedin.venice.client.store.streaming - package com.linkedin.venice.client.store.streaming
 
com.linkedin.venice.client.store.transport - package com.linkedin.venice.client.store.transport
 
com.linkedin.venice.client.utils - package com.linkedin.venice.client.utils
 
com.linkedin.venice.common - package com.linkedin.venice.common
 
com.linkedin.venice.compression - package com.linkedin.venice.compression
 
com.linkedin.venice.compression.protocol - package com.linkedin.venice.compression.protocol
 
com.linkedin.venice.compute - package com.linkedin.venice.compute
 
com.linkedin.venice.compute.protocol.request - package com.linkedin.venice.compute.protocol.request
 
com.linkedin.venice.compute.protocol.request.enums - package com.linkedin.venice.compute.protocol.request.enums
 
com.linkedin.venice.compute.protocol.request.router - package com.linkedin.venice.compute.protocol.request.router
 
com.linkedin.venice.compute.protocol.response - package com.linkedin.venice.compute.protocol.response
 
com.linkedin.venice.controller - package com.linkedin.venice.controller
 
com.linkedin.venice.controller.authorization - package com.linkedin.venice.controller.authorization
 
com.linkedin.venice.controller.datarecovery - package com.linkedin.venice.controller.datarecovery
 
com.linkedin.venice.controller.exception - package com.linkedin.venice.controller.exception
 
com.linkedin.venice.controller.helix - package com.linkedin.venice.controller.helix
 
com.linkedin.venice.controller.init - package com.linkedin.venice.controller.init
 
com.linkedin.venice.controller.kafka - package com.linkedin.venice.controller.kafka
 
com.linkedin.venice.controller.kafka.consumer - package com.linkedin.venice.controller.kafka.consumer
 
com.linkedin.venice.controller.kafka.protocol.admin - package com.linkedin.venice.controller.kafka.protocol.admin
 
com.linkedin.venice.controller.kafka.protocol.enums - package com.linkedin.venice.controller.kafka.protocol.enums
 
com.linkedin.venice.controller.kafka.protocol.serializer - package com.linkedin.venice.controller.kafka.protocol.serializer
 
com.linkedin.venice.controller.lingeringjob - package com.linkedin.venice.controller.lingeringjob
 
com.linkedin.venice.controller.migration - package com.linkedin.venice.controller.migration
 
com.linkedin.venice.controller.server - package com.linkedin.venice.controller.server
 
com.linkedin.venice.controller.spark - package com.linkedin.venice.controller.spark
 
com.linkedin.venice.controller.stats - package com.linkedin.venice.controller.stats
 
com.linkedin.venice.controller.supersetschema - package com.linkedin.venice.controller.supersetschema
 
com.linkedin.venice.controller.systemstore - package com.linkedin.venice.controller.systemstore
 
com.linkedin.venice.controller.util - package com.linkedin.venice.controller.util
 
com.linkedin.venice.controllerapi - package com.linkedin.venice.controllerapi
 
com.linkedin.venice.controllerapi.routes - package com.linkedin.venice.controllerapi.routes
 
com.linkedin.venice.d2 - package com.linkedin.venice.d2
 
com.linkedin.venice.D2 - package com.linkedin.venice.D2
 
com.linkedin.venice.datarecovery - package com.linkedin.venice.datarecovery
 
com.linkedin.venice.datarecovery.meta - package com.linkedin.venice.datarecovery.meta
 
com.linkedin.venice.etl - package com.linkedin.venice.etl
 
com.linkedin.venice.exceptions - package com.linkedin.venice.exceptions
 
com.linkedin.venice.exceptions.validation - package com.linkedin.venice.exceptions.validation
 
com.linkedin.venice.fastclient - package com.linkedin.venice.fastclient
 
com.linkedin.venice.fastclient.factory - package com.linkedin.venice.fastclient.factory
 
com.linkedin.venice.fastclient.meta - package com.linkedin.venice.fastclient.meta
 
com.linkedin.venice.fastclient.stats - package com.linkedin.venice.fastclient.stats
 
com.linkedin.venice.fastclient.transport - package com.linkedin.venice.fastclient.transport
 
com.linkedin.venice.fastclient.utils - package com.linkedin.venice.fastclient.utils
 
com.linkedin.venice.grpc - package com.linkedin.venice.grpc
 
com.linkedin.venice.guid - package com.linkedin.venice.guid
 
com.linkedin.venice.hadoop - package com.linkedin.venice.hadoop
 
com.linkedin.venice.hadoop.engine - package com.linkedin.venice.hadoop.engine
 
com.linkedin.venice.hadoop.exceptions - package com.linkedin.venice.hadoop.exceptions
 
com.linkedin.venice.hadoop.heartbeat - package com.linkedin.venice.hadoop.heartbeat
 
com.linkedin.venice.hadoop.input.kafka - package com.linkedin.venice.hadoop.input.kafka
 
com.linkedin.venice.hadoop.input.kafka.avro - package com.linkedin.venice.hadoop.input.kafka.avro
 
com.linkedin.venice.hadoop.input.kafka.chunk - package com.linkedin.venice.hadoop.input.kafka.chunk
 
com.linkedin.venice.hadoop.input.kafka.ttl - package com.linkedin.venice.hadoop.input.kafka.ttl
 
com.linkedin.venice.hadoop.input.recordreader - package com.linkedin.venice.hadoop.input.recordreader
 
com.linkedin.venice.hadoop.input.recordreader.avro - package com.linkedin.venice.hadoop.input.recordreader.avro
 
com.linkedin.venice.hadoop.input.recordreader.vson - package com.linkedin.venice.hadoop.input.recordreader.vson
 
com.linkedin.venice.hadoop.jobs - package com.linkedin.venice.hadoop.jobs
 
com.linkedin.venice.hadoop.mapreduce.common - package com.linkedin.venice.hadoop.mapreduce.common
 
com.linkedin.venice.hadoop.mapreduce.counter - package com.linkedin.venice.hadoop.mapreduce.counter
 
com.linkedin.venice.hadoop.mapreduce.datawriter.jobs - package com.linkedin.venice.hadoop.mapreduce.datawriter.jobs
 
com.linkedin.venice.hadoop.mapreduce.datawriter.map - package com.linkedin.venice.hadoop.mapreduce.datawriter.map
 
com.linkedin.venice.hadoop.mapreduce.datawriter.partition - package com.linkedin.venice.hadoop.mapreduce.datawriter.partition
 
com.linkedin.venice.hadoop.mapreduce.datawriter.reduce - package com.linkedin.venice.hadoop.mapreduce.datawriter.reduce
 
com.linkedin.venice.hadoop.mapreduce.datawriter.task - package com.linkedin.venice.hadoop.mapreduce.datawriter.task
 
com.linkedin.venice.hadoop.mapreduce.engine - package com.linkedin.venice.hadoop.mapreduce.engine
 
com.linkedin.venice.hadoop.output.avro - package com.linkedin.venice.hadoop.output.avro
 
com.linkedin.venice.hadoop.schema - package com.linkedin.venice.hadoop.schema
 
com.linkedin.venice.hadoop.spark - package com.linkedin.venice.hadoop.spark
 
com.linkedin.venice.hadoop.spark.datawriter.jobs - package com.linkedin.venice.hadoop.spark.datawriter.jobs
 
com.linkedin.venice.hadoop.spark.datawriter.partition - package com.linkedin.venice.hadoop.spark.datawriter.partition
 
com.linkedin.venice.hadoop.spark.datawriter.recordprocessor - package com.linkedin.venice.hadoop.spark.datawriter.recordprocessor
 
com.linkedin.venice.hadoop.spark.datawriter.task - package com.linkedin.venice.hadoop.spark.datawriter.task
 
com.linkedin.venice.hadoop.spark.datawriter.writer - package com.linkedin.venice.hadoop.spark.datawriter.writer
 
com.linkedin.venice.hadoop.spark.engine - package com.linkedin.venice.hadoop.spark.engine
 
com.linkedin.venice.hadoop.spark.input - package com.linkedin.venice.hadoop.spark.input
 
com.linkedin.venice.hadoop.spark.input.hdfs - package com.linkedin.venice.hadoop.spark.input.hdfs
 
com.linkedin.venice.hadoop.spark.utils - package com.linkedin.venice.hadoop.spark.utils
 
com.linkedin.venice.hadoop.ssl - package com.linkedin.venice.hadoop.ssl
 
com.linkedin.venice.hadoop.task - package com.linkedin.venice.hadoop.task
 
com.linkedin.venice.hadoop.task.datawriter - package com.linkedin.venice.hadoop.task.datawriter
 
com.linkedin.venice.hadoop.utils - package com.linkedin.venice.hadoop.utils
 
com.linkedin.venice.hadoop.validation - package com.linkedin.venice.hadoop.validation
 
com.linkedin.venice.helix - package com.linkedin.venice.helix
 
com.linkedin.venice.hooks - package com.linkedin.venice.hooks
 
com.linkedin.venice.httpclient - package com.linkedin.venice.httpclient
 
com.linkedin.venice.httpclient5 - package com.linkedin.venice.httpclient5
 
com.linkedin.venice.ingestion.control - package com.linkedin.venice.ingestion.control
 
com.linkedin.venice.ingestion.protocol - package com.linkedin.venice.ingestion.protocol
 
com.linkedin.venice.ingestion.protocol.enums - package com.linkedin.venice.ingestion.protocol.enums
 
com.linkedin.venice.io - package com.linkedin.venice.io
 
com.linkedin.venice.kafka.protocol - package com.linkedin.venice.kafka.protocol
 
com.linkedin.venice.kafka.protocol.enums - package com.linkedin.venice.kafka.protocol.enums
 
com.linkedin.venice.kafka.protocol.state - package com.linkedin.venice.kafka.protocol.state
 
com.linkedin.venice.kafka.validation - package com.linkedin.venice.kafka.validation
 
com.linkedin.venice.kafka.validation.checksum - package com.linkedin.venice.kafka.validation.checksum
 
com.linkedin.venice.listener - package com.linkedin.venice.listener
 
com.linkedin.venice.listener.grpc - package com.linkedin.venice.listener.grpc
 
com.linkedin.venice.listener.grpc.handlers - package com.linkedin.venice.listener.grpc.handlers
 
com.linkedin.venice.listener.request - package com.linkedin.venice.listener.request
 
com.linkedin.venice.listener.response - package com.linkedin.venice.listener.response
 
com.linkedin.venice.message - package com.linkedin.venice.message
 
com.linkedin.venice.meta - package com.linkedin.venice.meta
 
com.linkedin.venice.meta.systemstore.schemas - package com.linkedin.venice.meta.systemstore.schemas
 
com.linkedin.venice.metadata.response - package com.linkedin.venice.metadata.response
 
com.linkedin.venice.migration - package com.linkedin.venice.migration
 
com.linkedin.venice.offsets - package com.linkedin.venice.offsets
 
com.linkedin.venice.participant.protocol - package com.linkedin.venice.participant.protocol
 
com.linkedin.venice.participant.protocol.enums - package com.linkedin.venice.participant.protocol.enums
 
com.linkedin.venice.partitioner - package com.linkedin.venice.partitioner
 
com.linkedin.venice.persona - package com.linkedin.venice.persona
 
com.linkedin.venice.producer - package com.linkedin.venice.producer
 
com.linkedin.venice.producer.online - package com.linkedin.venice.producer.online
 
com.linkedin.venice.protocols - package com.linkedin.venice.protocols
 
com.linkedin.venice.pubsub - package com.linkedin.venice.pubsub
 
com.linkedin.venice.pubsub.adapter - package com.linkedin.venice.pubsub.adapter
 
com.linkedin.venice.pubsub.adapter.kafka - package com.linkedin.venice.pubsub.adapter.kafka
 
com.linkedin.venice.pubsub.adapter.kafka.admin - package com.linkedin.venice.pubsub.adapter.kafka.admin
 
com.linkedin.venice.pubsub.adapter.kafka.consumer - package com.linkedin.venice.pubsub.adapter.kafka.consumer
 
com.linkedin.venice.pubsub.adapter.kafka.producer - package com.linkedin.venice.pubsub.adapter.kafka.producer
 
com.linkedin.venice.pubsub.api - package com.linkedin.venice.pubsub.api
 
com.linkedin.venice.pubsub.api.exceptions - package com.linkedin.venice.pubsub.api.exceptions
 
com.linkedin.venice.pubsub.manager - package com.linkedin.venice.pubsub.manager
 
com.linkedin.venice.pulsar.sink - package com.linkedin.venice.pulsar.sink
 
com.linkedin.venice.pushmonitor - package com.linkedin.venice.pushmonitor
 
com.linkedin.venice.pushstatus - package com.linkedin.venice.pushstatus
 
com.linkedin.venice.pushstatushelper - package com.linkedin.venice.pushstatushelper
 
com.linkedin.venice.read - package com.linkedin.venice.read
 
com.linkedin.venice.read.protocol.request.router - package com.linkedin.venice.read.protocol.request.router
 
com.linkedin.venice.read.protocol.response - package com.linkedin.venice.read.protocol.response
 
com.linkedin.venice.read.protocol.response.streaming - package com.linkedin.venice.read.protocol.response.streaming
 
com.linkedin.venice.request - package com.linkedin.venice.request
 
com.linkedin.venice.router - package com.linkedin.venice.router
 
com.linkedin.venice.router.api - package com.linkedin.venice.router.api
 
com.linkedin.venice.router.api.path - package com.linkedin.venice.router.api.path
 
com.linkedin.venice.router.api.routing.helix - package com.linkedin.venice.router.api.routing.helix
 
com.linkedin.venice.router.exception - package com.linkedin.venice.router.exception
 
com.linkedin.venice.router.httpclient - package com.linkedin.venice.router.httpclient
 
com.linkedin.venice.router.stats - package com.linkedin.venice.router.stats
 
com.linkedin.venice.router.streaming - package com.linkedin.venice.router.streaming
 
com.linkedin.venice.router.throttle - package com.linkedin.venice.router.throttle
 
com.linkedin.venice.router.utils - package com.linkedin.venice.router.utils
 
com.linkedin.venice.routerapi - package com.linkedin.venice.routerapi
 
com.linkedin.venice.samza - package com.linkedin.venice.samza
 
com.linkedin.venice.schema - package com.linkedin.venice.schema
 
com.linkedin.venice.schema.avro - package com.linkedin.venice.schema.avro
 
com.linkedin.venice.schema.rmd - package com.linkedin.venice.schema.rmd
 
com.linkedin.venice.schema.rmd.v1 - package com.linkedin.venice.schema.rmd.v1
 
com.linkedin.venice.schema.vson - package com.linkedin.venice.schema.vson
 
com.linkedin.venice.schema.writecompute - package com.linkedin.venice.schema.writecompute
 
com.linkedin.venice.security - package com.linkedin.venice.security
 
com.linkedin.venice.serialization - package com.linkedin.venice.serialization
 
com.linkedin.venice.serialization.avro - package com.linkedin.venice.serialization.avro
 
com.linkedin.venice.serializer - package com.linkedin.venice.serializer
 
com.linkedin.venice.server - package com.linkedin.venice.server
 
com.linkedin.venice.service - package com.linkedin.venice.service
 
com.linkedin.venice.servicediscovery - package com.linkedin.venice.servicediscovery
 
com.linkedin.venice.standalone - package com.linkedin.venice.standalone
 
com.linkedin.venice.stats - package com.linkedin.venice.stats
 
com.linkedin.venice.status - package com.linkedin.venice.status
 
com.linkedin.venice.status.protocol - package com.linkedin.venice.status.protocol
 
com.linkedin.venice.status.protocol.enums - package com.linkedin.venice.status.protocol.enums
 
com.linkedin.venice.storage.protocol - package com.linkedin.venice.storage.protocol
 
com.linkedin.venice.store - package com.linkedin.venice.store
 
com.linkedin.venice.store.exception - package com.linkedin.venice.store.exception
 
com.linkedin.venice.store.rocksdb - package com.linkedin.venice.store.rocksdb
 
com.linkedin.venice.streaming - package com.linkedin.venice.streaming
 
com.linkedin.venice.system.store - package com.linkedin.venice.system.store
 
com.linkedin.venice.systemstore.schemas - package com.linkedin.venice.systemstore.schemas
 
com.linkedin.venice.tehuti - package com.linkedin.venice.tehuti
 
com.linkedin.venice.testng - package com.linkedin.venice.testng
 
com.linkedin.venice.throttle - package com.linkedin.venice.throttle
 
com.linkedin.venice.unit.kafka - package com.linkedin.venice.unit.kafka
 
com.linkedin.venice.unit.kafka.consumer - package com.linkedin.venice.unit.kafka.consumer
 
com.linkedin.venice.unit.kafka.consumer.poll - package com.linkedin.venice.unit.kafka.consumer.poll
 
com.linkedin.venice.unit.kafka.producer - package com.linkedin.venice.unit.kafka.producer
 
com.linkedin.venice.unit.matchers - package com.linkedin.venice.unit.matchers
 
com.linkedin.venice.utils - package com.linkedin.venice.utils
 
com.linkedin.venice.utils.collections - package com.linkedin.venice.utils.collections
 
com.linkedin.venice.utils.concurrent - package com.linkedin.venice.utils.concurrent
 
com.linkedin.venice.utils.lazy - package com.linkedin.venice.utils.lazy
 
com.linkedin.venice.utils.locks - package com.linkedin.venice.utils.locks
 
com.linkedin.venice.utils.metrics - package com.linkedin.venice.utils.metrics
 
com.linkedin.venice.utils.pools - package com.linkedin.venice.utils.pools
 
com.linkedin.venice.views - package com.linkedin.venice.views
 
com.linkedin.venice.writer - package com.linkedin.venice.writer
 
com.linkedin.venice.writer.update - package com.linkedin.venice.writer.update
 
combine(CallCompletion...) - Static method in interface com.linkedin.alpini.base.monitoring.CallCompletion
 
combine(AbstractQuantileEstimation.Data) - Method in class com.linkedin.alpini.base.statistics.LongStatsAggregator.LongData
 
command() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
command(String...) - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
command(List<String>) - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
Command - Class in com.linkedin.venice.datarecovery
 
Command - Enum in com.linkedin.venice
TODO: Merge this with ControllerRoute
Command() - Constructor for class com.linkedin.venice.datarecovery.Command
 
COMMAND - com.linkedin.venice.ingestion.protocol.enums.IngestionAction
 
Command.Params - Class in com.linkedin.venice.datarecovery
 
Command.Result - Class in com.linkedin.venice.datarecovery
 
commandComparator - Static variable in enum com.linkedin.venice.Command
 
commandType - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
0 => StartConsumption, 1 => StopConsumption, 2 => KillConsumption, 3 => ResetConsumption, 4 => IsPartitionConsuming, 5 => RemoveStorageEngine, 6 => RemovePartition, 7 => OpenStorageEngine, 8 => PromoteToLeader, 9 => DemoteToStandby
CommonConfigKeys - Class in com.linkedin.venice
Common config keys shared by venice-backend and venice-thin-client.
CommonConfigKeys() - Constructor for class com.linkedin.venice.CommonConfigKeys
 
commonValidityCheck() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
Compute operation validity check for projections, dot-product and cosine-similarity.
COMPACT_HEADER - Static variable in class com.linkedin.alpini.netty4.http2.CompactHeaderHandler
 
compactExceptionDescription(Throwable) - Static method in class com.linkedin.venice.utils.ExceptionUtils
 
compactExceptionDescription(Throwable, String) - Static method in class com.linkedin.venice.utils.ExceptionUtils
 
CompactHeaderHandler - Class in com.linkedin.alpini.netty4.http2
Handler for compacting Espresso headers to a single header entry.
CompactHeaderHandler(Class<?>, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.CompactHeaderHandler
Constructor.
comparator() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
COMPARATOR - Static variable in interface org.apache.avro.generic.DeterministicMapOrderDatumWriter
 
compare(byte[], byte[]) - Static method in class com.linkedin.venice.utils.ByteUtils
A comparator for byte arrays.
compare(byte[], int, int, byte[], int, int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
 
compare(DoubleQuantileEstimation.Sample, DoubleQuantileEstimation.Sample) - Method in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation
 
compare(GenericQuantileEstimation.Sample<T>, GenericQuantileEstimation.Sample<T>) - Method in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation
 
compare(LongQuantileEstimation.Sample, LongQuantileEstimation.Sample) - Method in class com.linkedin.alpini.base.statistics.LongQuantileEstimation
 
compare(KafkaInputMapperKey, KafkaInputMapperKey) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
 
compare(KafkaInputMapperKey, KafkaInputMapperKey) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputValueGroupingComparator
 
compare(Object, Object) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
Backport compareTo() method from SpecificRecordBase.
compare(Object, Object, Schema) - Method in class com.linkedin.davinci.schema.merge.AvroCollectionElementComparator
This function compares two objects using the provided schema.
compare(BytesWritable, BytesWritable) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
 
compare(Row, Row) - Method in class com.linkedin.venice.hadoop.spark.datawriter.partition.PartitionSorter
 
compare(SAMPLE, SAMPLE) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
compare(T, T) - Method in class com.linkedin.venice.utils.HashCodeComparator
 
COMPARE_STORE - com.linkedin.venice.Command
 
COMPARE_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
compareAndReturn(Object, Object) - Static method in class com.linkedin.davinci.replication.merge.MergeUtils
 
compareAndUpdate(ZkBaseDataAccessor<T>, String, int, DataUpdater<T>) - Static method in class com.linkedin.venice.utils.HelixUtils
 
compareAndUpdate(ZkBaseDataAccessor<T>, String, DataUpdater<T>) - Static method in class com.linkedin.venice.utils.HelixUtils
 
compareCacheConfig(Optional<ObjectCacheConfig>) - Method in class com.linkedin.davinci.DaVinciBackend
 
compareGenericData(Object, Object, Schema) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
Backport compare() method implementation from GenericData in avro v1.7
comparePosition(VeniceChangeCoordinate) - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
comparePosition(PubSubPosition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
comparePosition(PubSubPosition) - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
 
compareSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
 
compareSchema(Schema, Schema) - Method in interface com.linkedin.venice.controller.supersetschema.SupersetSchemaGenerator
Compare whether two schemas are equal or not with the consideration of superset schema.
compareSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
 
compareSchemaIgnoreFieldOrder(Schema, Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Compares two schema with possible re-ordering of the fields.
compareSpecificData(Object, Object, Schema) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
Backport compare() method implementation from SpecificData in avro v1.7
compareStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
compareStore(String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
compareStore(String, String, String, String) - Method in interface com.linkedin.venice.controller.Admin
Compare store metadata and version states between two fabrics.
compareStore(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
compareStore(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
compareTo(TimeValue) - Method in class com.linkedin.alpini.base.misc.TimeValue
 
compareTo(ConsumerAction) - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
compareTo(Version) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
compareTo(Version) - Method in class com.linkedin.venice.meta.VersionImpl
 
compareTo(PartitionStatus) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
compareTo(RouterKey) - Method in class com.linkedin.venice.router.api.RouterKey
 
compareTo(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string using the ASCII values of the characters.
compareTo(CharSequence) - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
compareUnsigned(byte[], byte[]) - Static method in class com.linkedin.venice.utils.ArrayUtils
This is mostly a copy of Arrays.compareUnsigned(T[], T[]) from Java 9.
COMPATIBLE - com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaCompatibilityType
 
ComplementSet<T> - Class in com.linkedin.venice.utils
A set that uses complement representation, which is useful when universal set cardinality is unknown.
ComplementSet(boolean, Set<T>) - Constructor for class com.linkedin.venice.utils.ComplementSet
 
CompletableFutureCallback - Class in com.linkedin.venice.writer
Compose a CompletableFuture and Callback together to be a CompletableFutureCallback type.
CompletableFutureCallback(CompletableFuture<Void>) - Constructor for class com.linkedin.venice.writer.CompletableFutureCallback
 
CompletableFutureTask<V> - Class in com.linkedin.alpini.base.concurrency
Created by acurtis on 4/4/17.
CompletableFutureTask(Runnable, V) - Constructor for class com.linkedin.alpini.base.concurrency.CompletableFutureTask
Creates a CompletableFutureTask that will, upon running, execute the given Runnable, and arrange that get will return the given result on successful completion.
CompletableFutureTask(Callable<V>) - Constructor for class com.linkedin.alpini.base.concurrency.CompletableFutureTask
Creates a CompletableFutureTask that will, upon running, execute the given Callable.
complete(HttpServerStatisticsHandler.Stats) - Method in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler
This method is invoked for every complete HttpServerStatisticsHandler.Stats object.
complete(Promise<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
complete(Promise<V>, Consumer<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
complete(T) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
COMPLETE_MIGRATION - com.linkedin.venice.Command
 
COMPLETE_MIGRATION - com.linkedin.venice.controllerapi.ControllerRoute
 
completeCoreWorkWithError(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
completeCoreWorkWithMessage(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
completed(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Consumption is completed for a store and partition.
completed(String, int, long, String) - Method in class com.linkedin.davinci.helix.StateModelIngestionProgressNotifier
 
completed(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
completed(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
completed(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
completed(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
completed(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
completed(String, int, long, String, Optional<LeaderFollowerStateType>) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
completed(String, int, long, String, Optional<LeaderFollowerStateType>) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
COMPLETED - com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
 
COMPLETED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
COMPLETED - com.linkedin.venice.pushmonitor.ExecutionStatus
For task, data is read and put into storage engine.
COMPLETED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
COMPLETED - com.linkedin.venice.status.PushJobDetailsStatus
 
completeExceptionally(Throwable) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
completeFuture(int, int, CompressionStrategy, byte[]) - Method in class com.linkedin.venice.client.store.transport.TransportClientCallback
 
completeFuture(Promise<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
COMPLETELY_UPDATED - com.linkedin.davinci.schema.merge.UpdateResultStatus
 
completeMigration(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
completeMigration(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
completeMigration(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
completeMigration(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
completeMigration(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
completePersistedToDBFuture(Exception) - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
Completion() - Constructor for class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor.Completion
 
completionReported - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether completion has been reported before
completionReported() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
COMPLEX - com.linkedin.alpini.base.concurrency.ConcurrentAccumulator.Mode
 
ComplexAccumulator<T,​A,​R> - Class in com.linkedin.alpini.base.concurrency
One or more variables that together maintain an accumulation.
ComplexAccumulator(Collector<T, A, R>) - Constructor for class com.linkedin.alpini.base.concurrency.ComplexAccumulator
 
componentType - Variable in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
0 => KafkaIngestionService, 1 => StorageService
compose(ByteBufAllocator, ByteBuf, ByteBuf) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Calculate the result of current + next.
composeFirst(ByteBufAllocator, ByteBuf) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Calculate the first ByteBuf which will be used in subsequent calls to AbstractCoalescingBufferQueue10294.compose(ByteBufAllocator, ByteBuf, ByteBuf).
composeIntoComposite(ByteBufAllocator, ByteBuf, ByteBuf) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Compose cumulation and next into a new CompositeByteBuf.
composeKafkaTopic(String, int) - Static method in interface com.linkedin.venice.meta.Version
 
composePartitionDbDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
composeRealTimeTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
composeRegionList(Set<String>) - Static method in class com.linkedin.venice.utils.RegionUtils
A helper function to compose a region list with RegionUtils.REGION_FILTER_LIST_SEPARATOR.
composeRouterRequest(String) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
composeRouterRequestInternal(String) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
composeRouterRequestInternal(String) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
composeRouterRequestInternal(String) - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
composeSnapshotDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
composeStoreDbDir(String, String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
composeStreamReprocessingTopic(String, int) - Static method in interface com.linkedin.venice.meta.Version
 
composeStreamReprocessingTopicFromVersionTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
composeTempRMDSSTFileDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
composeTempRMDSSTFileName(int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
composeTempSSTFileDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
composeTempSSTFileName(int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
composeVersionTopicFromStreamReprocessingTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
CompositePollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
A PollStrategy implementation which takes a queue of many poll strategies.
CompositePollStrategy(Queue<AbstractPollStrategy>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.CompositePollStrategy
 
compress(byte[]) - Method in class com.linkedin.venice.compression.GzipCompressor
 
compress(byte[]) - Method in class com.linkedin.venice.compression.NoopCompressor
 
compress(byte[]) - Method in class com.linkedin.venice.compression.VeniceCompressor
 
compress(byte[]) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
compress(byte[]) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
compress(ByteBuffer, int) - Method in class com.linkedin.venice.compression.GzipCompressor
 
compress(ByteBuffer, int) - Method in class com.linkedin.venice.compression.NoopCompressor
 
compress(ByteBuffer, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
 
compress(ByteBuffer, int) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
compressedValueSizeCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
COMPRESSION_DICTIONARY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
COMPRESSION_DICTIONARY_SAMPLE_SIZE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Sample size to collect for building dictionary: Can be assigned a max of 2GB as ZstdDictTrainer in ZSTD library takes in sample size as int
COMPRESSION_DICTIONARY_SIZE_LIMIT - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Maximum final dictionary size TODO add more details about the current limits
COMPRESSION_METRIC_COLLECTION_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config to enable/disable the feature to collect extra metrics wrt compression.
COMPRESSION_STRATEGIES - Static variable in class com.linkedin.venice.utils.DataProviderUtils
 
COMPRESSION_STRATEGY - com.linkedin.venice.Arg
 
COMPRESSION_STRATEGY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
COMPRESSION_STRATEGY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
compressionDictionary - Variable in class com.linkedin.venice.kafka.protocol.StartOfPush
The raw bytes of dictionary used to compress/decompress records.
compressionDictionary - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
The raw bytes of dictionary used to compress/decompress records.
compressionMetricCollectionEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
compressionProvider() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
compressionStrategy - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
compressionStrategy - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Using int because Avro Enums are not evolvable
compressionStrategy - Variable in class com.linkedin.venice.kafka.protocol.StartOfPush
What type of compression strategy the current push uses.
compressionStrategy - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
What type of compression strategy the current push are used.
compressionStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
compressionStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
compressionStrategy - Variable in class com.linkedin.venice.metadata.response.VersionProperties
The current version's compression strategy.
compressionStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Strategy used to compress/decompress Record's value, and default is 'NO_OP'
compressionStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
strategies used to compress/decompress Record's value, and default is 'NO_OP'
CompressionStrategy - Enum in com.linkedin.venice.compression
Enums of the strategies used to compress/decompress Record's value
COMPRESSIONSTRATEGY_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
 
CompressionUtils - Class in com.linkedin.alpini.netty4.compression
 
compressor - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
Compressor(PigzOutputStream) - Constructor for class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
compressorFactory - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
compressorFactory - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
CompressorFactory - Class in com.linkedin.venice.compression
 
CompressorFactory() - Constructor for class com.linkedin.venice.compression.CompressorFactory
 
compressorMap - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
CompressOutputStream - Class in com.linkedin.alpini.io
BackupOutputStream encapsulates an GZip compressor and provides methods to allow other threads to wait upon the completion of the file.
CompressOutputStream(int, ExecutorService, int, OutputStream) - Constructor for class com.linkedin.alpini.io.CompressOutputStream
Creates a compressed backup output stream built on top of the specified underlying output stream.
compute() - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
 
compute() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
This API allows performing transformations (projection, vector arithmetic and aggregations like count) on the values associated with the given set of keys.
compute() - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
compute(int, byte[], AbstractAvroChunkingAdapter<GenericRecord>, AvroStoreDeserializerCache<GenericRecord>, int, BinaryDecoder, ByteBuffer, GenericRecord, Map<String, Object>, ComputeRequestWrapper, Schema) - Method in class com.linkedin.davinci.VersionBackend
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.AvroBlackHoleResponseStoreClientImpl
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
 
compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.CountOperator
 
compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.DotProductOperator
 
compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.HadamardProductOperator
 
compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
 
compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.RetriableAvroGenericStoreClient
 
compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.StatsAvroGenericStoreClient
 
compute(Optional<ClientStats>, AvroGenericReadComputeStoreClient) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
compute(Optional<ClientStats>, AvroGenericReadComputeStoreClient) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
 
compute(Optional<ClientStats>, AvroGenericReadComputeStoreClient) - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
Deprecated.
 
compute(Optional<ClientStats>, Optional<ClientStats>, long) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
Deprecated.
compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
Deprecated.
compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
COMPUTE - com.linkedin.venice.meta.QueryAction
 
COMPUTE - com.linkedin.venice.read.RequestType
 
COMPUTE_REQUEST_CLIENT_KEY_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Compute request client key v1.
COMPUTE_REQUEST_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Compute request v1.
COMPUTE_REQUEST_V2 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Compute request v2.
COMPUTE_REQUEST_V3 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Compute request v3.
COMPUTE_REQUEST_V4 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Compute request v4.
COMPUTE_REQUEST_VERSION_V2 - Static variable in class com.linkedin.venice.VeniceConstants
Compute request version 2.
COMPUTE_REQUEST_VERSION_V3 - Static variable in class com.linkedin.venice.VeniceConstants
V3 contains all V2 operator + new Count operator
COMPUTE_REQUEST_VERSION_V4 - Static variable in class com.linkedin.venice.VeniceConstants
V4 contains all V3 operators + executeWithFilter
COMPUTE_RESPONSE_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Response record for compute v1
COMPUTE_ROUTER_REQUEST_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Router request key for read compute v1.
COMPUTE_STREAMING - com.linkedin.venice.read.RequestType
 
COMPUTE_VALID_HEADER_MAP - Static variable in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
computedAggregates - Variable in class com.linkedin.venice.kafka.protocol.EndOfSegment
A map containing the results of the aggregate computation strategies that were promised in the previous StartOfSegment ControlMessage.
ComputeGenericRecord - Class in com.linkedin.venice.client.store
A simple wrapper to throw exception when retrieving failed computation.
ComputeGenericRecord(GenericRecord, Schema) - Constructor for class com.linkedin.venice.client.store.ComputeGenericRecord
Schema of the original record that was used to compute the result
computeIfAbsent(int, IntFunction<? extends E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
computeIfAbsent(ConcurrentMap<K, V>, K, Function<? super K, ? extends V>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
ComputeIfAbsent on a ConcurrentHashMap should be a very light weight operation if the key already exists.
computeIfAbsent(ConcurrentMap<K, V>, K, Function<? super K, ? extends V>, BiConsumer<K, V>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
Accepts a mapping function to compute the value, and only register when the old value is not set.
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.linkedin.venice.utils.concurrent.VeniceConcurrentHashMap
TODO: Remove this class once the code has completely migrated to JDK11+ The native `computeIfAbsent` function implemented in Java could have contention when the value already exists ConcurrentHashMap.computeIfAbsent(Object, Function); the contention could become very bad when lots of threads are trying to "computeIfAbsent" on the same key, which is a known Java bug: https://bugs.openjdk.java.net/browse/JDK-8161372 This internal VeniceConcurrentHashMap mitigate such contention by trying to get the value first before invoking "computeIfAbsent", which brings great optimization if the major workload is trying to get the same key over and over again; however, we speculate that this optimization might not be ideal for the workload that most keys are unique, so be cautious about the workload before adopting the VeniceConcurrentHashMap.
computeIfNotNull(T, Consumer<T>) - Static method in class com.linkedin.venice.utils.Utils
Run "function" on "t" if "t" is not null
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
ComputeJob - Interface in com.linkedin.venice.hadoop.jobs
An interface to abstract executing and monitoring a compute job running on any batch compute engine
ComputeJob.Status - Enum in com.linkedin.venice.hadoop.jobs
 
ComputeOperation - Class in com.linkedin.venice.compute.protocol.request
 
ComputeOperation() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeOperation
Default constructor.
ComputeOperation(Integer, Object) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeOperation
All-args constructor.
ComputeOperationType - Enum in com.linkedin.venice.compute.protocol.request.enums
 
computeQuantile(double) - Method in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation
 
computeQuantile(long) - Method in class com.linkedin.alpini.base.statistics.LongQuantileEstimation
 
computeQuantile(long, TimeUnit) - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
computeQuantile(SAMPLE) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
Computes the quantile which the given sample v is a member.
computeQuantile(SAMPLE) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Data
 
computeQuantile(T) - Method in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation
 
ComputeRecordStreamDecoder<K,​V> - Class in com.linkedin.venice.client.store.streaming
 
ComputeRecordStreamDecoder(List<K>, TrackingStreamingCallback<K, V>, Executor, RecordDeserializer<StreamingFooterRecordV1>, RecordDeserializer<V>) - Constructor for class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
 
ComputeRequest - Class in com.linkedin.venice.compute.protocol.request
This record only contains the operations and result schema, and keys will be appended after during serialization
ComputeRequest() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequest
Default constructor.
ComputeRequest(List<ComputeOperation>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequest
All-args constructor.
ComputeRequestBuilder<K> - Interface in com.linkedin.venice.client.store
 
computeRequestClientKeySerializer - Variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
ComputeRequestContext<K,​V> - Class in com.linkedin.venice.fastclient
Keep track of the progress of a compute request .
ComputeRequestContext(int, boolean) - Constructor for class com.linkedin.venice.fastclient.ComputeRequestContext
 
ComputeRequestV1 - Class in com.linkedin.venice.compute.protocol.request
This record only contains the operations and result schema, and keys will be appended after during serialization
ComputeRequestV1() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
Default constructor.
ComputeRequestV1(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
All-args constructor.
ComputeRequestV2 - Class in com.linkedin.venice.compute.protocol.request
This record only contains the operations and result schema, and keys will be appended after during serialization
ComputeRequestV2() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
Default constructor.
ComputeRequestV2(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
All-args constructor.
ComputeRequestV3 - Class in com.linkedin.venice.compute.protocol.request
This record only contains the operations and result schema, and keys will be appended after during serialization
ComputeRequestV3() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
Default constructor.
ComputeRequestV3(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
All-args constructor.
ComputeRequestV4 - Class in com.linkedin.venice.compute.protocol.request
This record only contains the operations and result schema, and keys will be appended after during serialization
ComputeRequestV4() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
Default constructor.
ComputeRequestV4(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
All-args constructor.
ComputeRequestWrapper - Class in com.linkedin.venice.compute
This class is used by the client to encapsulate the information it needs about a compute request.
ComputeRequestWrapper(Schema, Schema, String, List<ComputeOperation>, boolean) - Constructor for class com.linkedin.venice.compute.ComputeRequestWrapper
 
ComputeResponseRecordV1 - Class in com.linkedin.venice.compute.protocol.response
This record used to store the response per key
ComputeResponseRecordV1() - Constructor for class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
Default constructor.
ComputeResponseRecordV1(Integer, ByteBuffer) - Constructor for class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
All-args constructor.
ComputeResponseRecordV1ChunkedDeserializer - Class in com.linkedin.venice.client.store.streaming
 
ComputeResponseRecordV1ChunkedDeserializer() - Constructor for class com.linkedin.venice.client.store.streaming.ComputeResponseRecordV1ChunkedDeserializer
 
ComputeResponseWrapper - Class in com.linkedin.venice.listener.response
 
ComputeResponseWrapper(int) - Constructor for class com.linkedin.venice.listener.response.ComputeResponseWrapper
 
computeResult(List<ComputeOperation>, List<Schema.Field>, Map<String, Object>, GenericRecord, GenericRecord) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
computeResult(List<ComputeOperation>, List<Schema.Field>, Map<String, Object>, GenericRecord, Schema) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
ComputeRouterRequestKeyV1 - Class in com.linkedin.venice.compute.protocol.request.router
This field will store all the related info for one key
ComputeRouterRequestKeyV1() - Constructor for class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Default constructor.
ComputeRouterRequestKeyV1(Integer, ByteBuffer, Integer) - Constructor for class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
All-args constructor.
ComputeRouterRequestWrapper - Class in com.linkedin.venice.listener.request
ComputeRouterRequestWrapper encapsulates a POST request for read-compute from routers.
computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in interface com.linkedin.davinci.storage.StorageMetadataService
 
computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
 
computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.venice.offsets.InMemoryStorageMetadataService
 
ComputeUtils - Class in com.linkedin.venice.compute
This class provides utilities for float-vector operations, and it also handles PrimitiveFloatList transparently to the user of this class.
ComputeUtils() - Constructor for class com.linkedin.venice.compute.ComputeUtils
 
computeWithKeyPrefixFilter(byte[], int, StreamingCallback<GenericRecord, GenericRecord>, ComputeRequestWrapper, AbstractAvroChunkingAdapter<GenericRecord>, RecordDeserializer<GenericRecord>, GenericRecord, BinaryDecoder, Map<String, Object>, Schema) - Method in class com.linkedin.davinci.VersionBackend
 
computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
 
computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
 
computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
concat(CharSequence...) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Concatenates this string and the specified string.
concat(Iterable<? extends T>...) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
concat(Iterator<? extends T>...) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
concat(Iterator<T>...) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
ConcurrencyUtils - Class in com.linkedin.venice.utils.concurrent
 
CONCURRENT_BATCH_PUSH - com.linkedin.venice.exceptions.ErrorType
 
CONCURRENT_BATCH_PUSH - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
CONCURRENT_INIT_ROUTINES_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Enable the concurrent execution of the controllers' init routines, which are executed when a controller becomes a cluster leader.
ConcurrentAccumulator<T,​A,​R> - Class in com.linkedin.alpini.base.concurrency
One or more variables that together maintain an accumulation.
ConcurrentAccumulator(ConcurrentAccumulator.Mode, Collector<T, A, R>) - Constructor for class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
 
ConcurrentAccumulator(Collector<T, A, R>) - Constructor for class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
 
ConcurrentAccumulator.Mode - Enum in com.linkedin.alpini.base.concurrency
 
ConcurrentBatchPushException - Exception in com.linkedin.venice.exceptions
 
ConcurrentBatchPushException(String) - Constructor for exception com.linkedin.venice.exceptions.ConcurrentBatchPushException
 
ConcurrentLinkedBlockingQueue<E> - Class in com.linkedin.alpini.base.concurrency
A BlockingQueue implementation which uses a collection of concurrent Queues per thread in order to reduce the hotspot of a highly contended mutex or atomic reference.
ConcurrentLinkedBlockingQueue() - Constructor for class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
Default constructor with a pollSleepMillis of 10 milliseconds.
ConcurrentLinkedBlockingQueue(long) - Constructor for class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
Constructor which permits specifying the pollSleepMillis
ConcurrentRef<T> - Class in com.linkedin.venice.utils
 
ConcurrentRef(Consumer<T>) - Constructor for class com.linkedin.venice.utils.ConcurrentRef
 
ConcurrentRef(T, Consumer<T>) - Constructor for class com.linkedin.venice.utils.ConcurrentRef
 
Config() - Constructor for class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
Config() - Constructor for class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
CONFIG_DIRECTORY - Static variable in class com.linkedin.davinci.config.StoreBackendConfig
 
ConfigBuilder<C> - Interface in com.linkedin.alpini.consts.config
Used for creation and verification of configs Forked from com.linkedin.databus.core.util @ r293057
ConfigConstants - Class in com.linkedin.venice
 
ConfigConstants() - Constructor for class com.linkedin.venice.ConfigConstants
 
ConfigEntity(String, T, String) - Constructor for class com.linkedin.venice.utils.Utils.ConfigEntity
 
ConfigKeys - Class in com.linkedin.venice
 
configMap - Variable in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
A map that contains all the configs in runtime
configs - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
configs - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
ConfigurationException - Exception in com.linkedin.venice.exceptions
Thrown when a config property is invalid or missing
ConfigurationException(Exception) - Constructor for exception com.linkedin.venice.exceptions.ConfigurationException
 
ConfigurationException(String) - Constructor for exception com.linkedin.venice.exceptions.ConfigurationException
 
ConfigurationException(String, Exception) - Constructor for exception com.linkedin.venice.exceptions.ConfigurationException
 
configure(EngineTaskConfigProvider) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
Configures the task with the given EngineTaskConfigProvider.
configure(VeniceProperties) - Method in interface com.linkedin.venice.hadoop.jobs.ComputeJob
 
configure(VeniceProperties) - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
configure(VeniceProperties, PushJobSetting) - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
configure(VeniceProperties, PushJobSetting) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
configure(VeniceProperties, PushJobSetting) - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
configure(String, VeniceProperties, MetricsRepository, SchemaReader, SchemaReader) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
configure(Map<String, ?>) - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.DefaultSerializer
 
configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.KafkaKeySerializer
 
configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.StringSerializer
Configure this class.
configure(Map<String, ?>, boolean) - Method in interface com.linkedin.venice.serialization.VeniceKafkaSerializer
Configure this class.
configure(Schema, Schema) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
Configure the record serializers
configure(JobConf) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormatCombiner
 
configure(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.map.AbstractVeniceMapper
 
configure(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
 
configure(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
configure(JobConf) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
CONFIGURE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
CONFIGURE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.controllerapi.ControllerRoute
 
CONFIGURE_INCREMENTAL_PUSH_FOR_CLUSTER - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
Deprecated.
We do not support incremental push policy anymore.
CONFIGURE_NATIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
CONFIGURE_NATIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.controllerapi.ControllerRoute
 
CONFIGURE_STORE_VIEW - com.linkedin.venice.Command
 
configureActiveActiveReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
Enable/disable active active replications for certain stores (batch only, hybrid only, incremental push, hybrid or incremental push, all) in a cluster.
configureActiveActiveReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
configureActiveActiveReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
configureActiveActiveReplicationForCluster(boolean, String, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
ConfigureActiveActiveReplicationForCluster - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
ConfigureActiveActiveReplicationForCluster() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Default constructor.
ConfigureActiveActiveReplicationForCluster(CharSequence, CharSequence, Boolean, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
All-args constructor.
ConfigureIncrementalPushForCluster - Class in com.linkedin.venice.controller.kafka.protocol.admin
A command to migrate all incremental push stores in a cluster to a specific incremental push policy.
ConfigureIncrementalPushForCluster() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Default constructor.
ConfigureIncrementalPushForCluster(CharSequence, Integer, Integer, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
All-args constructor.
configureNativeReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
Enable/disable native replications for certain stores (batch only, hybrid only, incremental push, hybrid or incremental push, all) in a cluster.
configureNativeReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
configureNativeReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
configureNativeReplicationForCluster(boolean, String, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
ConfigureNativeReplicationForCluster - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
ConfigureNativeReplicationForCluster() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Default constructor.
ConfigureNativeReplicationForCluster(CharSequence, CharSequence, Boolean, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
All-args constructor.
configurePipeline(ChannelHandlerContext, String) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormatCombiner
 
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
 
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
Allow implementations of this class to configure task-specific stuff.
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
 
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
configureWebSockets(Map<String, WebSocketHandlerWrapper>, Optional<Long>) - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
 
confirmStores(Set<String>) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
 
connect() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
connect() - Method in class io.netty.bootstrap.InstrumentedBootstrap
Connect a Channel to the remote peer.
connect() - Method in class io.netty.bootstrap.ResolveAllBootstrap
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
connect(ChannelHandlerContext, SocketAddress, SocketAddress, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.RateLimitConnectHandler
 
connect(SocketAddress) - Method in class io.netty.bootstrap.InstrumentedBootstrap
Connect a Channel to the remote peer.
connect(SocketAddress) - Method in class io.netty.bootstrap.ResolveAllBootstrap
 
connect(SocketAddress, SocketAddress) - Method in class io.netty.bootstrap.InstrumentedBootstrap
Connect a Channel to the remote peer.
connect(SocketAddress, SocketAddress) - Method in class io.netty.bootstrap.ResolveAllBootstrap
 
connectChannel(Bootstrap) - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Bootstrap a new Channel.
connectChannel(Bootstrap) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
connectChannel(Bootstrap, Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Initiate establishing a new connection with the provided bootstrap.
connectChannel(Bootstrap, Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Bootstrap a new Channel.
connectChannel(Bootstrap, Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
connectChannel0(Bootstrap) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
connectChannel0(Bootstrap, Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
CONNECTED - com.linkedin.venice.meta.InstanceStatus
 
connectHelixManager(SafeHelixManager, int, int) - Static method in class com.linkedin.venice.utils.HelixUtils
Try to connect Helix Manger.
connectInProgress() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
CONNECTION_ERROR - com.linkedin.venice.exceptions.ErrorType
 
CONNECTION_ERROR - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
connectionChannel(ChannelHandlerContext) - Static method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
ConnectionControlHandler - Class in com.linkedin.alpini.netty4.handlers
A ChannelHandler which regulates the number of open connections by disabling the parent socket auto-read config when the number of active connections exceeds the limit value.
ConnectionControlHandler(int) - Constructor for class com.linkedin.alpini.netty4.handlers.ConnectionControlHandler
 
ConnectionControlHandler(IntSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.ConnectionControlHandler
 
connectionLimit(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
connectionLimit(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
connectionLimit(IntSupplier) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
connectionLimit(IntSupplier) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
ConnectionLimitHandler - Class in com.linkedin.alpini.netty4.handlers
 
ConnectionLimitHandler(int) - Constructor for class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
Construct with a preset connection limit.
ConnectionLimitHandler(IntSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
 
connectionScheme(ChannelHandlerContext) - Static method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
connectionSchemeAttribute(ChannelHandlerContext) - Static method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
CONSISTENT_HASH - com.linkedin.venice.meta.RoutingStrategy
 
CONSTANT_PARTITION - Static variable in class com.linkedin.venice.partitioner.ConstantVenicePartitioner
 
Constants() - Constructor for class com.linkedin.venice.kafka.protocol.enums.MessageType.Constants
 
ConstantVenicePartitioner - Class in com.linkedin.venice.partitioner
 
ConstantVenicePartitioner(VeniceProperties) - Constructor for class com.linkedin.venice.partitioner.ConstantVenicePartitioner
 
ConstantVenicePartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.partitioner.ConstantVenicePartitioner
 
construct(ChannelPoolManager, ChannelPoolHandler, EventLoopGroup, InetSocketAddress) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolFactory
Constructs a new ChannelPool which must connect to the specified address.
construct(ChannelPoolManager, ChannelPoolHandler, EventLoopGroup, InetSocketAddress) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
construct(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, IntSupplier, int, boolean) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
constructChunksContainer(ChunkedValueManifest) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
constructChunksContainer(ChunkedValueManifest) - Method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
 
constructChunksContainer(ChunkedValueManifest) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
Used to construct the right kind of {@param CHUNKS_CONTAINER} container (according to the query code) to hold a large value which needs to be incrementally re-assembled from many smaller chunks.
constructChunksContainer(ChunkedValueManifest) - Method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
 
constructClusterControllerClient(String, String) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
constructClusterControllerClient(String, String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
constructHttpClusterDiscoveryResponse(String, String, String) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructHttpMultiSchemaIdResponse(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructHttpMultiSchemaResponse(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructHttpSchemaResponse(String, int, String) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructInputDataInfoProvider() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
constructManagedPool(ChannelPoolHandler, InetSocketAddress) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
constructMultiSchemaIdResponseInBytes(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructMultiSchemaResponseInBytes(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructRouterPipelineFactory(ScatterGatherRequestHandler4<H, P, K, R>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
constructSchemaResponseInBytes(String, int, String) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructShutdown(SyncShutdownable) - Method in class com.linkedin.alpini.base.registry.SyncShutdownableAdapter
 
constructShutdown(R) - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
The constructed runnable must call AbstractShutdownableResource.signalShutdownInitiated() method to indicate that shutdown has started.
constructStoreResponse(int, byte[]) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
constructValue(byte[], int, int, RecordDeserializer<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
constructValue(byte[], int, int, RecordDeserializer<VALUE>, VeniceCompressor) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
 
constructValue(byte[], int, T, BinaryDecoder, ReadResponse, int, int, StoreDeserializerCache<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
constructValue(byte[], int, VALUE, BinaryDecoder, ReadResponse, int, int, StoreDeserializerCache<VALUE>, VeniceCompressor) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
Used to wrap a small {@param fullBytes} value fetched from the storage engine into the right type of {@param VALUE} class needed by the query code.
constructValue(int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
 
constructValue(int, byte[]) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
This function can be implemented by the adapters which need fewer parameters.
constructValue(int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
 
constructValue(int, CHUNKS_CONTAINER) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
This function can be implemented by the adapters which need fewer parameters.
constructValue(int, CompositeByteBuf) - Method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
 
constructValue(int, ByteBuffer) - Method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
 
constructValue(CHUNKS_CONTAINER, VALUE, BinaryDecoder, ReadResponse, int, int, StoreDeserializerCache<VALUE>, VeniceCompressor) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
Used to wrap a large value re-assembled with the use of a {@param CHUNKS_CONTAINER} into the right type of {@param VALUE} class needed by the query code.
constructValue(ChunkedValueInputStream, T, BinaryDecoder, ReadResponse, int, int, StoreDeserializerCache<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
constructVeniceWriter(Properties, VeniceWriterOptions) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
consume() - Method in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
 
consume(String, int, long) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
 
CONSUMED_RECORD_END_TO_END_PROCESSING_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
ConsumedDataReceiver<MESSAGE> - Interface in com.linkedin.davinci.ingestion.consumption
An abstraction of a receiver of data consumed from a message queue.
ConsumerAction - Class in com.linkedin.davinci.kafka.consumer
The class is used to asynchronously trigger behavior changes in the StoreIngestionTask.
ConsumerAction(ConsumerActionType, PubSubTopicPartition, int, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
ConsumerAction(ConsumerActionType, PubSubTopicPartition, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
ConsumerAction(ConsumerActionType, PubSubTopicPartition, int, Optional<LeaderFollowerStateType>, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
consumerActionSequenceNumber - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
consumerActionsQueue - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
ConsumerActionType - Enum in com.linkedin.davinci.kafka.consumer
An Enum enumerating all valid types of ConsumerAction.
consumerBatchUnsubscribe(Set<PubSubTopicPartition>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
consumeRemotely - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether the node is consuming remotely for this partition
consumeRemotely() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
consumerHasAnySubscription() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
consumerHasSubscription(PubSubTopic, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
consumerResetOffset(PubSubTopic, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
consumerSubscribe(PubSubTopicPartition, long, String) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
ConsumerSubscriptionCleaner - Class in com.linkedin.davinci.kafka.consumer
Encapsulates the logic for deciding if a given topic-partition should be unsubscribed and, in that case, executing the unsubscription.
ConsumerSubscriptionCleaner(long, int, TopicExistenceChecker, Supplier<Set<PubSubTopicPartition>>, IntConsumer, Consumer<Set<PubSubTopicPartition>>, Time) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerSubscriptionCleaner
 
consumerToConsumptionTask - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
consumerUnSubscribe(PubSubTopic, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
consumerUnSubscribeAllTopics(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
Unsubscribe from all the topics being consumed for the partition in partitionConsumptionState
consumerUnSubscribeAllTopics(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
ConsumptionStateSnapshot - Class in com.linkedin.venice.admin.protocol.response
Type describes all the version attributes
ConsumptionStateSnapshot() - Constructor for class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Default constructor.
ConsumptionStateSnapshot(Integer, Boolean, Boolean, Object, Boolean, Boolean, Boolean, Boolean, CharSequence, Boolean, Long, Boolean, Long) - Constructor for class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
All-args constructor.
contains(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Determines if this String contains the sequence of characters in the CharSequence passed.
contains(CharSequence) - Method in interface com.linkedin.alpini.base.misc.Headers
 
contains(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
contains(CharSequence) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
contains(CharSequence, CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Determine if a contains b in a case sensitive manner.
contains(CharSequence, CharSequence, boolean) - Method in interface com.linkedin.alpini.base.misc.Headers
 
contains(CharSequence, CharSequence, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
contains(CharSequence, CharSequence, boolean) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
contains(Object) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
contains(Object) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Returns true if this list contains the specified element.
contains(Object) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
contains(Object) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
contains(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
contains(String, String, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
contains(T) - Method in class com.linkedin.venice.utils.ComplementSet
 
contains(T) - Method in class com.linkedin.venice.utils.ExpiringSet
 
containsAll(Collection<?>) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
containsAll(Collection<?>) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
containsAll(Collection<?>) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
containsAllContentEqualsIgnoreCase(Collection<CharSequence>, Collection<CharSequence>) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Determine if a contains all of the values in b using ByteBufAsciiString.contentEqualsIgnoreCase(CharSequence, CharSequence) to compare values.
containsConfig(String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
containsContentEqualsIgnoreCase(Collection<CharSequence>, CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Determine if collection contains value and using ByteBufAsciiString.contentEqualsIgnoreCase(CharSequence, CharSequence) to compare values.
containsHeader(String) - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
 
containsHelixResource(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
containsHelixResource(String, String) - Method in interface com.linkedin.venice.meta.StoreCleaner
This purpose of the function is to check if the given resource exists in the Helix cluster.
containsHybridVersion(List<Version>) - Static method in interface com.linkedin.venice.meta.Version
 
containsIgnoreCase(CharSequence, CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Determine if a contains b in a case insensitive manner.
containsKafkaTopic(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
containsKafkaTopic(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Whether this repository contains routing data for given kafka topic or not.
containsKey(Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns true if this map contains a mapping for the specified key.
containsKey(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
containsOnlyOneCollection(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Utility function that checks to make sure that given a union schema, there only exists 1 collection type amongst the provided types.
containsPartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Return true or false based on whether a given partition exists within this storage engine
containsPartition(int, PartitionerConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
containsPersona(String) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
 
containsResource(String) - Method in class com.linkedin.venice.helix.ResourceAssignment
Deprecated.
containsResource(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Check if a resource exists in a cluster by checking its ideal state.
containsResource(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
containsRunningConsumption(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
containsRunningConsumption(VeniceStoreVersionConfig) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Check whether there is a running consumption task for given store.
containsRunningConsumption(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
containsRunningConsumption(String) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Check whether there is a running consumption task for given store version topic.
containsTopic(PubSubTopic) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Checks if a Kafka topic exists.
containsTopic(PubSubTopic) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Checks if a PubSub topic exists.
containsTopic(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
containsTopic(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
containsTopicAndAllPartitionsAreOnline(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
containsTopicAndAllPartitionsAreOnline(PubSubTopic, Integer) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
This is an extensive check to mitigate an edge-case where a topic is not yet created in all the brokers.
containsTopicCached(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Retry up to a maximum number of attempts to get the expected result.
containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean, Duration, Duration, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
 
containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean, Duration, Duration, Duration) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
containsTopicWithPartitionCheck(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Checks if a topic exists and has the given partition
containsTopicWithPartitionCheck(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Checks if a PubSub topic exists and has the given partition
containsTopicWithPartitionCheck(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
containsTopicWithPartitionCheckExpectationAndRetry(PubSubTopicPartition, int, boolean) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
 
containsTopicWithPartitionCheckExpectationAndRetry(PubSubTopicPartition, int, boolean, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
 
containsValue(Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns true if this map maps one or more keys to the specified value.
containsVersion(int) - Method in class com.linkedin.venice.meta.AbstractStore
 
containsVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
containsVersion(int) - Method in interface com.linkedin.venice.meta.Store
 
content() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
content() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
content() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
content() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
content() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
CONTENT_LENGTH - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
CONTENT_LOCATION - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
CONTENT_TYPE - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
ContentDecompressor - Class in com.linkedin.alpini.netty4.compression
 
ContentDecompressor() - Constructor for class com.linkedin.alpini.netty4.compression.ContentDecompressor
 
ContentDecompressResult - Class in com.linkedin.venice.router.api
A POJO to store the response content and additional compression related metadata.
ContentDecompressResult(ByteBuf, CompressionStrategy, long) - Constructor for class com.linkedin.venice.router.api.ContentDecompressResult
 
contentEquals(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares a CharSequence to this String to determine if their contents are equal.
contentEquals(CharSequence, CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Returns true if the content of both CharSequence's are equals.
contentEqualsIgnoreCase(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string ignoring the case of the characters and returns true if they are equal.
contentEqualsIgnoreCase(CharSequence, CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Returns true if both CharSequence's are equals when ignore the case.
context(boolean) - Method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
The default implementation for the anonymous classes below.
context(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
CONTROL_MESSAGE - com.linkedin.venice.kafka.protocol.enums.MessageType
 
CONTROL_MESSAGE_KAFKA_KEY_LENGTH - Static variable in class com.linkedin.venice.message.KafkaKey
For control messages, the Key part of the KafkaKey includes the producer GUID, segment and sequence number.
CONTROL_MESSAGE_KEY_HEADER_BYTE - Static variable in class com.linkedin.venice.kafka.protocol.enums.MessageType.Constants
 
CONTROLLER - Static variable in class com.linkedin.venice.acl.VeniceComponent
 
CONTROLLER_ADD_VERSION_VIA_ADMIN_PROTOCOL - Static variable in class com.linkedin.venice.ConfigKeys
Flag to indicate whether to perform add version and start of ingestion via the admin protocol.
CONTROLLER_AUTO_MATERIALIZE_DAVINCI_PUSH_STATUS_SYSTEM_STORE - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_AUTO_MATERIALIZE_META_SYSTEM_STORE - Static variable in class com.linkedin.venice.ConfigKeys
This config controls whether to make an empty push to materialize meta system store for newly created user stores if possible.
CONTROLLER_BACKUP_VERSION_DEFAULT_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
The following config is to control the default retention time in milliseconds if it is not specified in store level.
CONTROLLER_BACKUP_VERSION_METADATA_FETCH_BASED_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
The following config is to control whether to enable backup version cleanup based on router and server current version being served.
CONTROLLER_BACKUP_VERSION_RETENTION_BASED_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
The following config is to control whether to enable backup version cleanup based on retention policy or not at cluster level.
CONTROLLER_CLUSTER - Static variable in class com.linkedin.venice.ConfigKeys
Cluster name for all parent controllers
CONTROLLER_CLUSTER_LEADER_HAAS - Static variable in class com.linkedin.venice.ConfigKeys
Flag to indicate if the controller cluster leader will be amongst one of the local Helix as a library controllers or a Helix as a service controller running remotely.
CONTROLLER_CLUSTER_REPLICA - Static variable in class com.linkedin.venice.ConfigKeys
Venice uses a helix cluster to assign controllers to each named venice cluster.
CONTROLLER_CLUSTER_ZK_ADDRESSS - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_DEFAULT_READ_QUOTA_PER_ROUTER - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_DISABLE_PARENT_REQUEST_TOPIC_FOR_STREAM_PUSHES - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_DISABLE_PARENT_TOPIC_TRUNCATION_UPON_COMPLETION - Static variable in class com.linkedin.venice.ConfigKeys
Test only config used to disable parent topic truncation upon job completion.
CONTROLLER_DISABLED_REPLICA_ENABLER_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_DISABLED_ROUTES - Static variable in class com.linkedin.venice.ConfigKeys
List of forbidden admin paths
CONTROLLER_EARLY_DELETE_BACKUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_ENABLE_BATCH_PUSH_FROM_ADMIN_IN_CHILD - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable batch push (including GF job) from Admin in Child Controller.
CONTROLLER_ENABLE_DISABLED_REPLICA_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
The following config is to control whether to turn on disabled replica enabler service.
CONTROLLER_ENFORCE_SSL - Static variable in class com.linkedin.venice.ConfigKeys
Whether controller should enforce SSL.
CONTROLLER_HAAS_SUPER_CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
The super cluster name for HAAS.
CONTROLLER_HEARTBEAT_INSTANCE_NAME - Static variable in class com.linkedin.venice.common.PushStatusStoreUtils
 
CONTROLLER_IN_AZURE_FABRIC - Static variable in class com.linkedin.venice.ConfigKeys
Whether the controller is in Azure fabric.
CONTROLLER_JETTY_CONFIG_OVERRIDE_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
Prefix of configs to configure Jetty server in Controller.
CONTROLLER_MIN_SCHEMA_COUNT_TO_KEEP - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_PARENT_EXTERNAL_SUPERSET_SCHEMA_GENERATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether the superset schema generation in Parent Controller should be done via passed callback or not.
CONTROLLER_PARENT_MODE - Static variable in class com.linkedin.venice.ConfigKeys
Whether current controller is parent or not
CONTROLLER_PARENT_SYSTEM_STORE_HEARTBEAT_CHECK_WAIT_TIME_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
The wait time before validating system store heartbeat during system store health check in parent controller.
CONTROLLER_PARENT_SYSTEM_STORE_REPAIR_CHECK_INTERVAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Frequency to run system store health check in parent controller.
CONTROLLER_PARENT_SYSTEM_STORE_REPAIR_RETRY_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
The maximum retry count for parent controller to fix a bad system store.
CONTROLLER_PARENT_SYSTEM_STORE_REPAIR_SERVICE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to check system store health in parent controller.
CONTROLLER_REQUEST_RETRY_ATTEMPTS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
CONTROLLER_SCHEMA_VALIDATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Sets the default for whether or not do schema validation for all stores
CONTROLLER_SSL_CERTIFICATE_ATTRIBUTE_NAME - Static variable in class com.linkedin.venice.VeniceConstants
In a HttpServletRequest, we can get the client certificate by retrieving the following attribute.
CONTROLLER_SSL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
This config defines whether SSL is enabled in controller.
CONTROLLER_STORE_GRAVEYARD_CLEANUP_DELAY_MINUTES - Static variable in class com.linkedin.venice.ConfigKeys
When store graveyard cleanup is enabled, delete the graveyard znode if it has not been changed for a specific time.
CONTROLLER_STORE_GRAVEYARD_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable graveyard cleanup for batch-only store at cluster level.
CONTROLLER_STORE_GRAVEYARD_CLEANUP_SLEEP_INTERVAL_BETWEEN_LIST_FETCH_MINUTES - Static variable in class com.linkedin.venice.ConfigKeys
Sleep interval between each graveyard list fetch from ZK in StoreGraveyardCleanup service.
CONTROLLER_SYSTEM_SCHEMA_CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
The name of the cluster that should host the special stores used to serve system schemas.
CONTROLLER_SYSTEM_STORE_ACL_SYNCHRONIZATION_DELAY_MS - Static variable in class com.linkedin.venice.ConfigKeys
The delay in ms between each synchronization attempt between the Venice store acls and its corresponding system store acls if any synchronization is needed.
CONTROLLER_UNUSED_SCHEMA_CLEANUP_INTERVAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_UNUSED_VALUE_SCHEMA_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Enable automatic removal of old unused schemas.
CONTROLLER_ZK_SHARED_DAVINCI_PUSH_STATUS_SYSTEM_SCHEMA_STORE_AUTO_CREATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
CONTROLLER_ZK_SHARED_META_SYSTEM_SCHEMA_STORE_AUTO_CREATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to automatically create zk shared metadata system store in Controller or not
ControllerApiConstants - Class in com.linkedin.venice.controllerapi
 
ControllerApiConstants() - Constructor for class com.linkedin.venice.controllerapi.ControllerApiConstants
 
ControllerClient - Class in com.linkedin.venice.controllerapi
 
ControllerClient(String, String) - Constructor for class com.linkedin.venice.controllerapi.ControllerClient
 
ControllerClient(String, String, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.ControllerClient
 
ControllerClientBackedSystemSchemaInitializer - Class in com.linkedin.venice.system.store
 
ControllerClientBackedSystemSchemaInitializer(AvroProtocolDefinition, String, Schema, UpdateStoreQueryParams, boolean, Optional<SSLFactory>, String, String, String, boolean) - Constructor for class com.linkedin.venice.system.store.ControllerClientBackedSystemSchemaInitializer
 
ControllerClientFactory - Class in com.linkedin.venice.controllerapi
 
ControllerClientFactory() - Constructor for class com.linkedin.venice.controllerapi.ControllerClientFactory
 
controllerD2ServiceName - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
controllerRequestWithRetry(Supplier<ControllerResponse>, int) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
ControllerResponse - Class in com.linkedin.venice.controllerapi
Extend this class to create response objects for the controller Any fields that must be in all responses can go here.
ControllerResponse() - Constructor for class com.linkedin.venice.controllerapi.ControllerResponse
 
controllerRetries - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
ControllerRoute - Enum in com.linkedin.venice.controllerapi
 
ControllerRoutes - Class in com.linkedin.venice.controller.server
 
ControllerRoutes(boolean, Optional<DynamicAccessController>, PubSubTopicRepository) - Constructor for class com.linkedin.venice.controller.server.ControllerRoutes
 
controllerStatusPollRetries - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
ControllerTransport - Class in com.linkedin.venice.controllerapi
 
ControllerTransport(Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.ControllerTransport
 
ControlMessage - Class in com.linkedin.venice.kafka.protocol
ControlMessage payloads contain metadata about the stream of data, for validation and debuggability purposes.
ControlMessage() - Constructor for class com.linkedin.venice.kafka.protocol.ControlMessage
Default constructor.
ControlMessage(Integer, Map<CharSequence, CharSequence>, Object) - Constructor for class com.linkedin.venice.kafka.protocol.ControlMessage
All-args constructor.
ControlMessageDumper - Class in com.linkedin.venice
 
ControlMessageDumper(PubSubConsumerAdapter, String, int, int, int) - Constructor for class com.linkedin.venice.ControlMessageDumper
 
controlMessageType - Variable in class com.linkedin.venice.kafka.protocol.ControlMessage
Using int because Avro Enums are not evolvable.
ControlMessageType - Enum in com.linkedin.venice.kafka.protocol.enums
A simple enum to map the values of ControlMessage.controlMessageType N.B.: We maintain this enum manually because Avro's auto-generated enums do not support evolution (i.e.: adding values) properly.
controlMessageUnion - Variable in class com.linkedin.venice.kafka.protocol.ControlMessage
This contains the ControlMessage data which is specific to each type of ControlMessage.
convert(String) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
Deprecated.
convert(Schema) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
Deprecated.
CONVERT_VSON_SCHEMA - com.linkedin.venice.Command
 
convertCharSequenceMapToStringMap(Map<CharSequence, CharSequence>) - Static method in class com.linkedin.venice.utils.CollectionUtils
 
convertFromValueRecordSchema(Schema) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
This method is the only entry point! Convert schema of a store value to its write-compute schema.
convertFromValueRecordSchemaStr(String) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
 
convertHelixMessageToVeniceMessage(Message) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
Convert Helix message to Venice Message.
convertHostnameToMetricName(String) - Static method in class com.linkedin.venice.stats.StatsUtils
 
convertInstanceToZNRecord(Instance) - Static method in class com.linkedin.venice.helix.HelixInstanceConverter
 
convertKey(String, Schema) - Static method in class com.linkedin.venice.client.store.QueryTool
 
convertLatencyFromNSToMS(long) - Static method in class com.linkedin.venice.utils.LatencyUtils
 
convertLiveInstances(Collection<LiveInstance>) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
convertPartialUpdateToFullPut(Pair<Integer, Integer>, Object) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
convertPubSubMessageToPubSubChangeEventMessage(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PubSubTopicPartition) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
convertSizeFromLiteral(String) - Static method in class com.linkedin.venice.utils.VeniceProperties
 
convertStringMapToCharSequenceMap(Map<String, String>) - Static method in class com.linkedin.venice.utils.CollectionUtils
 
convertTo(TimeUnit) - Method in class com.linkedin.alpini.base.misc.TimeValue
Converts this TimeValue to another TimeValue with a different TimeUnit.
convertToKafkaSpecificHeaders(PubSubMessageHeaders) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaUtils
 
convertToSecureUrl(URL) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
Deprecated. 
convertToSecureUrl(URL, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
Deprecated. 
convertVeniceChangeCoordinateToStringAndEncode(VeniceChangeCoordinate) - Static method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
convertVeniceMessageToHelixMessage(StatusMessage) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
Convert Venice message to Helix message.
convertZNRecordToInstance(ZNRecord) - Static method in class com.linkedin.venice.helix.HelixInstanceConverter
 
copy() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
copy() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
copy() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
copy() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
copy() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
copy() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
copy() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
copy() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
copy(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
copy(ByteBuf, int, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
copy(HttpHeaders) - Static method in enum com.linkedin.alpini.netty4.misc.HttpUtils
Returns a deap copy of the passed in HttpHeaders.
copy(InputStream, OutputStream) - Static method in enum com.linkedin.alpini.io.IOUtils
 
copy(InputStream, OutputStream, byte[]) - Static method in enum com.linkedin.alpini.io.IOUtils
 
copy(InputStream, OutputStream, int) - Static method in enum com.linkedin.alpini.io.IOUtils
 
COPY - com.linkedin.alpini.netty4.misc.NettyUtils.ReadMode
 
copyAndCompose(ByteBufAllocator, ByteBuf, ByteBuf) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Compose cumulation and next into a new ByteBufAllocator.ioBuffer().
copyByteArray(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
 
copyKafkaSASLProperties(VeniceProperties, Properties, boolean) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
copyKafkaSASLProperties(Properties, Properties, boolean) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
copyOverStoreMetadata(String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
copyOverStoreSchemasAndConfigs(Admin) - Method in class com.linkedin.venice.controller.server.NewClusterBuildOutRoutes
 
copyOverStoreSchemasAndConfigs(String, String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
copyOverStoreSchemasAndConfigs(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
copyOverStoreSchemasAndConfigs(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
copyTo(AbstractCoalescingBufferQueue10294) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Copy all pending entries in this queue into the destination queue.
CorruptDataException - Exception in com.linkedin.venice.exceptions.validation
This exception is thrown when we detect corrupt data in the Kafka stream.
CorruptDataException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.CorruptDataException
 
CorruptDataException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.validation.CorruptDataException
 
COSINE_SIMILARITY - com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
 
COSINE_SIMILARITY_RESULT_SCHEMA - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
COSINE_SIMILARITY_SPEC - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
cosineSimilarity(String, List<Float>, String) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
cosineSimilarity(String, List<Float>, String) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Setup cosine-similarity operation.
CosineSimilarity - Class in com.linkedin.venice.compute.protocol.request
 
CosineSimilarity() - Constructor for class com.linkedin.venice.compute.protocol.request.CosineSimilarity
Default constructor.
CosineSimilarity(CharSequence, List<Float>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.CosineSimilarity
All-args constructor.
CosineSimilarityOperator - Class in com.linkedin.venice.compute
 
CosineSimilarityOperator() - Constructor for class com.linkedin.venice.compute.CosineSimilarityOperator
 
cosSimilarityParam - Variable in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
The passed feature vector, which will be used to execute cosine-similarity calculation against the field in the original value record
count(String, String) - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
 
count(String, String) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Set up compute operation.
count(Iterator<?>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
Count - Class in com.linkedin.venice.compute.protocol.request
 
Count() - Constructor for class com.linkedin.venice.compute.protocol.request.Count
Default constructor.
Count(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.Count
All-args constructor.
COUNT - com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
 
countAceEntries() - Method in class com.linkedin.venice.authorization.AclBinding
count the number of AceEntries in the AclBinding
CounterBackedMapReduceDataWriterTaskTracker - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.task
An interface to retrieve metrics related to data writer tasks after a MapReduce job has completed.
CounterBackedMapReduceDataWriterTaskTracker(Counters) - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
CounterQueue<T extends RetryCounter> - Class in com.linkedin.alpini.base.misc
A queue implemented with a circular buffer of AtomicReferences Example of using: 1.
CounterQueue(int, Map<String, CounterQueue<T>>, Supplier<T>) - Constructor for class com.linkedin.alpini.base.misc.CounterQueue
Initialize the queue and register itself to the queue map.
CountOperator - Class in com.linkedin.venice.compute
 
CountOperator() - Constructor for class com.linkedin.venice.compute.CountOperator
 
crc32(int, byte[], int, int) - Static method in class com.linkedin.alpini.base.hash.Crc32
 
Crc32 - Class in com.linkedin.alpini.base.hash
CRC32 algorithm as used by Deflate.
Crc32() - Constructor for class com.linkedin.alpini.base.hash.Crc32
 
CRC32 - com.linkedin.venice.kafka.validation.checksum.CheckSumType
Deprecated.
Crc32C - Class in com.linkedin.alpini.base.hash
A pure-java implementation of the CRC32 checksum that uses the CRC32-C polynomial, the same polynomial used by iSCSI and implemented on many Intel chipsets supporting SSE4.2.
Crc32C() - Constructor for class com.linkedin.alpini.base.hash.Crc32C
Create a new PureJavaCrc32 object.
CRC32CheckSum - Class in com.linkedin.venice.kafka.validation.checksum
Running checksum implementations based on CRC32.
CRC32CheckSum() - Constructor for class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
 
create() - Static method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
create() - Method in interface com.linkedin.alpini.base.pool.AsyncPool.LifeCycle
 
create() - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleFilter
 
create() - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
create() - Method in class com.linkedin.alpini.base.pool.impl.RateLimitedCreateLifeCycle
 
create() - Static method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
 
create(int, byte[]) - Static method in class com.linkedin.davinci.store.record.ValueRecord
 
create(int, ByteBuf) - Static method in class com.linkedin.davinci.store.record.ValueRecord
 
create(AsyncPool.LifeCycle<T>, QOSPolicy.StaticConfig, Executor, int, int, int, long, TimeUnit) - Static method in interface com.linkedin.alpini.base.pool.AsyncQOSPool
 
create(AsyncPool.LifeCycle<T>, Executor, int, int, int, int, long, TimeUnit) - Static method in interface com.linkedin.alpini.base.pool.AsyncPool
 
create(VeniceProperties, boolean, PubSubMessageDeserializer, String) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapterFactory
 
create(VeniceProperties, boolean, PubSubMessageDeserializer, String) - Method in interface com.linkedin.venice.pubsub.PubSubConsumerAdapterFactory
 
create(VeniceProperties, PubSubTopicRepository) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapterFactory
 
create(VeniceProperties, PubSubTopicRepository) - Method in interface com.linkedin.venice.pubsub.PubSubAdminAdapterFactory
 
create(VeniceProperties, String, String) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapterFactory
 
create(VeniceProperties, String, String) - Method in interface com.linkedin.venice.pubsub.PubSubProducerAdapterFactory
 
create(F, S) - Static method in class com.linkedin.venice.utils.Pair
Deprecated.
Static factory method that, unlike the constructor, performs generic inference saving some typing.
create(String...) - Static method in class com.linkedin.alpini.io.ExternalCommand
Creates an external process from the command.
create(List<String>) - Static method in class com.linkedin.alpini.io.ExternalCommand
Creates an external process from the command.
create(ZkBaseDataAccessor<T>, String, T) - Static method in class com.linkedin.venice.utils.HelixUtils
 
create(ZkBaseDataAccessor<T>, String, T, int) - Static method in class com.linkedin.venice.utils.HelixUtils
 
create(Routes, StaticFilesConfiguration, ExceptionMapper, boolean) - Method in class com.linkedin.venice.controller.spark.VeniceSparkServerFactory
 
CREATE_STORAGE_PERSONA - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
CREATE_STORAGE_PERSONA - com.linkedin.venice.controllerapi.ControllerRoute
 
CREATE_TOPIC_RETRIABLE_EXCEPTIONS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
createAdminFactory(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
createAndVerifyStoreInAllRegions(String, ControllerClient, List<ControllerClient>) - Static method in class com.linkedin.venice.utils.TestUtils
 
createBinaryDecoder(byte[], int, int, BinaryDecoder) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
createBinaryDecoder(byte[], int, int, BinaryDecoder) - Method in class com.linkedin.venice.serialization.avro.OptimizedKafkaValueSerializer
 
createCallTracker() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
createCallTracker() - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
createCheckpoint(RocksDB) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
createChildren(List<PropertyKey>, List<T>) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
createClusterReadLock() - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
 
createClusterWriteLock() - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
 
createCollectionTimeStampSchema(String, String, Schema) - Static method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
Create a RECORD that keeps track of collection field's update metadata.
createCompressorWithDictionary(byte[], int) - Method in class com.linkedin.venice.compression.CompressorFactory
 
createConfig(String, String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
createConnectionManager(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
 
createConsumerFactory(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
createControllerLeader(LiveInstance) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
createControllerMessage(Message) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
CREATED - com.linkedin.venice.meta.VersionStatus
 
createD2GetRequest(String) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
createD2GetRequest(String, Map<String, String>) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
createD2PostRequest(String, Map<String, String>, byte[]) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
createDecoder(int, int, int, boolean, int) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
 
createDefaultPersona() - Static method in class com.linkedin.venice.utils.TestStoragePersonaUtils
 
createdTime - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
createdTime - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Timestamp when this store was created.
createdTime - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Time when this version was created.
createEncoder() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
 
createExecution(String) - Method in class com.linkedin.venice.controller.AdminCommandExecutionTracker
Create an execution context of a command.
createFlattenedUnionSchema(List<Schema>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
 
createGenericRecord(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Create a GenericRecord from a given schema.
createHeartbeatSender(String, VeniceProperties, ControllerClient, Optional<Properties>) - Method in class com.linkedin.venice.hadoop.heartbeat.DefaultPushJobHeartbeatSenderFactory
 
createHeartbeatSender(String, VeniceProperties, ControllerClient, Optional<Properties>) - Method in class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSenderFactory
 
createHeartbeatSender(String, VeniceProperties, ControllerClient, Optional<Properties>) - Method in interface com.linkedin.venice.hadoop.heartbeat.PushJobHeartbeatSenderFactory
Create a heartbeat sender
createHelixResourceAndStartMonitoring(String, String, Version) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Create Helix-resources for a given storage node cluster and starts monitoring a new push.
createHostAcquireCallTracker() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
createHostAcquireCallTracker(String) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
createHostBusyCallTracker() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
createHostBusyCallTracker(String) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
createHttp2MultiplexHandler(ChannelHandler) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
createHttp2PingSendHandler() - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
createHttp2PipelineInitializer() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
createHttp2PipelineInitializer(Consumer<ChannelPipeline>) - Method in class com.linkedin.venice.listener.VeniceHttp2PipelineInitializerBuilder
This function will leverage the existing HTTP/1.1 pipeline for both HTTP/1.1 and HTTP/2.
createHttp2StreamChannelBootstrap(Channel) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
createHttp2StreamFrameToHttpObjectCodec(boolean) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
createIngestionTaskReport() - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
createIngestionTaskReport(IngestionReportType, String, int, long, String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
createIngestionTaskReport(IngestionReportType, String, int, String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
createIngestionTaskReport(String, int) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
createInstance(String) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
createInvalidMessage() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
 
createInvalidMessage() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
 
createInvalidMessage() - Method in class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartDecode
 
createInvalidMessage() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
createInvalidMessage() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
 
createInvalidMessage(long, long) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
 
createKafkaConsumerProperties(Properties, String, boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Override the CommonClientConfigs.BOOTSTRAP_SERVERS_CONFIG config with a remote Kafka bootstrap url.
createKafkaConsumerService(Properties) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
Create a new KafkaConsumerService given consumerProperties which must contain a value for "bootstrap.servers".
createKey() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
createKeySchema(String, SchemaEntry) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
createKeySerializer() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
Clients using different protocols for deserialized data (e.g VSON, Proto, etc) can override this method to serialize the respective POJO to Avro bytes
createKeySerializer() - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
Deprecated.
 
createKillAction(PubSubTopic, int) - Static method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
Create a kill consumer action.
createLatestPingCallTimeTracker() - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
createListenerService(StorageEngineRepository, ReadOnlyStoreRepository, ReadOnlySchemaRepository, CompletableFuture<HelixCustomizedViewOfflinePushRepository>, IngestionMetadataRetriever, ReadMetadataRetriever, VeniceServerConfig, MetricsRepository, Optional<SSLFactory>, Optional<StaticAccessController>, Optional<DynamicAccessController>, DiskHealthCheckService, StorageEngineBackedCompressorFactory, Optional<ResourceReadUsageTracker>) - Method in class com.linkedin.venice.server.VeniceServer
 
createMaintenance(MaintenanceSignal) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
createMergeConflictResolver(StringAnnotatedStoreSchemaCache, RmdSerDe, String) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolverFactory
 
createMergeConflictResolver(StringAnnotatedStoreSchemaCache, RmdSerDe, String, boolean, boolean) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolverFactory
 
createMessage(ByteBufAsciiString[]) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
createMessage(String[]) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
 
createMessage(String[]) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
 
createMessage(String[]) - Method in class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartDecode
 
createMessage(String[]) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
createMessage(String[]) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
 
createMessage(String[], boolean, long, long) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
 
createMultiThreadedMetricsRepository() - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
 
createNewStateModel(String, String) - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
This method will be invoked only once per partition per session
createNewStateModel(String, String) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory
 
createNewStateModel(String, String) - Method in class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
 
createNewStateModel(String, String) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
 
createNewStore(String, String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
createNewStore(String, String, String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
createNewStoreWithParameters(String, String, String, String, UpdateStoreQueryParams) - Method in class com.linkedin.venice.controllerapi.ControllerClient
Simplified API that wraps together the store create and update functionalities with some clean up functionality
createNewSystemStore(String, String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
createOfflinePushStatusAndItsPartitionStatuses(OfflinePushStatus) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
createOfflinePushStatusAndItsPartitionStatuses(OfflinePushStatus) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Create offline push and its partition statues on persistent storage.
createOptimizedBinaryDecoder(byte[], int, int) - Method in class org.apache.avro.io.OptimizedBinaryDecoderFactory
This function will create an optimized binary decoder.
createOptimizedBinaryDecoder(ByteBuffer) - Method in class org.apache.avro.io.OptimizedBinaryDecoderFactory
 
createPause(PauseSignal) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
createPerFieldTimestampRecord(Schema, long, GenericRecord) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolver
 
createPersona(StoragePersona) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
 
createPersona(String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
Note that this method does not return an error if the persona already exists.
createPingCallTracker() - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
createProducer(ClientConfig, VeniceProperties, ICProvider) - Static method in class com.linkedin.venice.producer.online.OnlineProducerFactory
 
createProducerCallback(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
createProducerCallback(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
createProducerFactory(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
createProducerFactory(Properties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
createQueueAcquireCallTracker() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
Deprecated.
createQueueBusyCallTracker() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
Deprecated.
createReader(InputPartition) - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputPartitionReaderFactory
 
createReaderFactory() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputScan
 
createRecordIterator(VeniceProperties, InputPartition) - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputPartitionReader
 
createRecordIterator(VeniceProperties, InputPartition) - Method in class com.linkedin.venice.hadoop.spark.input.VeniceAbstractPartitionReader
 
createRepushInfo(Version, String, String, String) - Static method in class com.linkedin.venice.controllerapi.RepushInfo
 
createRequestHandler(ThreadPoolExecutor, ThreadPoolExecutor, StorageEngineRepository, ReadOnlyStoreRepository, ReadOnlySchemaRepository, IngestionMetadataRetriever, ReadMetadataRetriever, DiskHealthCheckService, boolean, boolean, int, StorageEngineBackedCompressorFactory, Optional<ResourceReadUsageTracker>) - Method in class com.linkedin.venice.listener.ListenerService
 
createRouterClusterConfig() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
createRouterClusterConfig() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
 
createRouterRequestKey(ByteBuffer, int, int) - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
createRouterRequestKey(ByteBuffer, int, int) - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
createRouterRequestKey(ByteBuffer, int, int) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
Create a router request key.
createSecureSocketConnector(Server, String, int, SslStores, boolean) - Static method in class com.linkedin.venice.controller.spark.VeniceSocketConnectorFactory
Creates a ssl jetty socket jetty.
createSingleThreadedMetricsRepository() - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
 
createSingleThreadedMetricsRepository(long, long) - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
 
createSnapshot() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Creates a snapshot of the current state of the storage if the blob transfer feature is enabled via the store configuration
createSnapshot() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
createSnapshot() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
createSnapshot() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
createSnapshot() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
createSnapshot(RocksDB) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
createSocketConnector(Server, String, int, boolean) - Static method in class com.linkedin.venice.controller.spark.VeniceSocketConnectorFactory
Creates an ordinary, non-secured Jetty server jetty.
createSpecificVersionTopic(String, String, Version) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Create the corresponding version topic based on the provided Version
createSslEngine(ByteBufAllocator, SocketAddress) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
 
createSSLEngine(ByteBufAllocator, boolean) - Method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
 
createSSLEngine(ByteBufAllocator, boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
createSSLEngine(ByteBufAllocator, String, int, boolean) - Method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
 
createSSLEngine(ByteBufAllocator, String, int, boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
createSSLFactory(boolean, String, Lazy<Properties>) - Static method in class com.linkedin.venice.hadoop.utils.VPJSSLUtils
 
createStateModelDef(StateModelDefinition) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
 
createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngine
 
createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
createStoragePersona(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
 
createStoragePersona(String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
createStoragePersona(String, String, long, Set<String>, Set<String>) - Method in interface com.linkedin.venice.controller.Admin
 
createStoragePersona(String, String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
createStoragePersona(String, String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Creates a new persona with the given parameters.
CreateStoragePersona - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
CreateStoragePersona() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Default constructor.
CreateStoragePersona(CharSequence, CharSequence, Long, List<CharSequence>, List<CharSequence>) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
All-args constructor.
createStore(Admin) - Method in class com.linkedin.venice.controller.server.CreateStore
 
createStore(String, String, String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
createStore(String, String, String, String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
createStore(String, String, String, String, String, boolean, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
 
createStore(String, String, String, String, String, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Create a new ZK store and its configuration in the store repository and create schemas in the schema repository.
createStore(String, String, String, String, String, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Create a store by sending STORE_CREATION admin message to the Kafka admin topic, sending META_SYSTEM_STORE_AUTO_CREATION_VALIDATION admin message, and performing initialization steps for using authorize server to manage ACLs for the input store.
CreateStore - Class in com.linkedin.venice.controller.server
 
CreateStore(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.CreateStore
 
createStoreReadLock(String) - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
 
createStoreSchemaFetcher(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
createStoreWriteLock(String) - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
 
createStoreWriteLockOnly(String) - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
 
createSystemProducer(String, String, String, Version.PushType, String, String, boolean, Config, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Deprecated.
Left in to maintain backward compatibility
createSystemProducer(String, String, String, Version.PushType, String, String, Config, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Deprecated.
Left in to maintain backward compatibility
createSystemProducer(String, String, String, String, Version.PushType, String, String, boolean, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Construct a new instance of VeniceSystemProducer
createSystemProducer(String, String, String, String, Version.PushType, String, String, boolean, Config, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Construct a new instance of VeniceSystemProducer
createTestStore(String, String, long) - Static method in class com.linkedin.venice.utils.TestUtils
 
createThreadPool(int, String, int) - Method in class com.linkedin.venice.listener.ListenerService
 
createThreadPool(int, String, int, BlockingQueueType) - Static method in class com.linkedin.venice.utils.concurrent.ThreadPoolFactory
 
createTopic(PubSubTopic, int, int, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Create a topic, and block until the topic is created, with a default timeout of 30000, after which this function will throw a VeniceException.
createTopic(PubSubTopic, int, int, boolean, boolean, Optional<Integer>) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
createTopic(PubSubTopic, int, int, boolean, boolean, Optional<Integer>, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Create a topic, and block until the topic is created, with a default timeout of 30000, after which this function will throw a VeniceException.
createTopic(PubSubTopic, int, int, long, boolean, Optional<Integer>, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Create a topic, and block until the topic is created, with a default timeout of 30000, after which this function will throw a VeniceException.
createTopic(PubSubTopic, int, int, PubSubTopicConfiguration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Creates a new topic in the PubSub system with the given parameters.
createTopic(PubSubTopic, int, int, PubSubTopicConfiguration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Creates a new topic in the PubSub system with the given parameters.
createTopic(PubSubTopic, int, int, PubSubTopicConfiguration) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
createTopic(String, int) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
 
createUnresolved(String) - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
createUnresolved(InetSocketAddress) - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
createValue() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
createVeniceControllerCluster(boolean) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Create and configure the Venice controller cluster.
createVeniceControllerCluster(boolean) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
createVeniceStorageCluster(String, Map<String, String>, boolean) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Create and configure the Venice storage cluster.
createVeniceStorageCluster(String, Map<String, String>, boolean) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
createVeniceStorageClusterResources(String, String, int, int) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Create resources for a given storage node cluster.
createVeniceStorageClusterResources(String, String, int, int) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
createVeniceWriter(VeniceWriterOptions) - Method in class com.linkedin.venice.writer.VeniceWriterFactory
 
CreateVersion - Class in com.linkedin.venice.controller.server
This class will add a new version to the given store.
CreateVersion(boolean, Optional<DynamicAccessController>, boolean, boolean) - Constructor for class com.linkedin.venice.controller.server.CreateVersion
 
createVersionSpecificCompressorIfNotExist(CompressionStrategy, String, byte[]) - Method in class com.linkedin.venice.compression.CompressorFactory
 
createVersionSpecificCompressorIfNotExist(CompressionStrategy, String, byte[], int) - Method in class com.linkedin.venice.compression.CompressorFactory
 
createVersionWithBatchData(ControllerClient, String, String, String, Stream<Map.Entry>, int, PubSubProducerAdapterFactory, Map<String, String>) - Static method in class com.linkedin.venice.utils.TestUtils
 
createVersionWithBatchData(ControllerClient, String, String, String, Stream<Map.Entry>, PubSubProducerAdapterFactory, Map<String, String>) - Static method in class com.linkedin.venice.utils.TestUtils
 
creationTime - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
credentials - Variable in class com.linkedin.venice.grpc.VeniceGrpcServer
 
ctx() - Method in class io.netty.handler.codec.EspressoMessageAggregator
 
CURRENT_STORE_STATES - com.linkedin.venice.common.StoreMetadataType
 
CURRENT_VERSION - com.linkedin.venice.controllerapi.routes.V1Get
 
CURRENT_VERSION - com.linkedin.venice.controllerapi.routes.V1Put
 
CURRENT_VERSION - com.linkedin.venice.meta.QueryAction
 
CURRENT_VERSION_IS_NEWER - com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
 
CURRENT_VERSION_STATES - com.linkedin.venice.common.StoreMetadataType
 
currentContext() - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
 
currentProtocolVersion - Variable in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
The protocol version that is currently in use.
CurrentStoreStates - Class in com.linkedin.venice.meta.systemstore.schemas
This type of store metadata describes the current states of the store in a given fabric and Venice cluster.
CurrentStoreStates() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
Default constructor.
CurrentStoreStates(StoreProperties) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
All-args constructor.
currentTimeMillis() - Static method in enum com.linkedin.alpini.base.misc.Time
 
currentValue - Variable in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
The current value of this record as of this change event.
currentValuePayloadSize - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
currentVersion - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
currentVersion - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
currentVersion - Variable in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
The version number that is currently used to serve read traffic
currentVersion - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
currentVersion - Variable in class com.linkedin.venice.metadata.response.VersionProperties
Current version number
currentVersion - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
The number of version which is used currently.
currentVersion - Variable in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
currentVersionHighWatermarks - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
currentVersionLastHeartbeat - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
CurrentVersionRequest - Class in com.linkedin.venice.listener.request
 
CurrentVersionResponse - Class in com.linkedin.venice.controllerapi
 
CurrentVersionResponse() - Constructor for class com.linkedin.venice.controllerapi.CurrentVersionResponse
 
currentVersionStates - Variable in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
An array of version states describing the current state of an given fabric.
CurrentVersionStates - Class in com.linkedin.venice.meta.systemstore.schemas
This type of store metadata describes the current version states of the store in a given fabric and Venice cluster.
CurrentVersionStates() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
Default constructor.
CurrentVersionStates(List<StoreVersionState>, Integer) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
All-args constructor.
CUSTOMIZEDVIEW - com.linkedin.venice.helix.HelixViewPropertyType
 
CV_PUSH_MONITOR_FOR_LF_STORE - com.linkedin.venice.pushmonitor.PushMonitorType
 

D

D2_SERVICE_DISCOVERY_RESPONSE_V2_ENABLED - Static variable in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponseV2
Deprecated.
D2_ZK_HOSTS_ADDRESS - Static variable in class com.linkedin.venice.ConfigKeys
ZooKeeper address of d2 client.
D2_ZK_HOSTS_PREFIX - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
This config specifies the prefix for d2 zk hosts config.
d2Client - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
D2ClientFactory - Class in com.linkedin.venice.d2
 
D2ClientFactory() - Constructor for class com.linkedin.venice.d2.D2ClientFactory
 
D2ClientUtils - Class in com.linkedin.venice.D2
 
D2ClientUtils() - Constructor for class com.linkedin.venice.D2.D2ClientUtils
 
D2ControllerClient - Class in com.linkedin.venice.controllerapi
 
D2ControllerClient(String, String, D2Client) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
 
D2ControllerClient(String, String, D2Client, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
 
D2ControllerClient(String, String, String, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
 
D2ControllerClientFactory - Class in com.linkedin.venice.controllerapi
 
D2ControllerClientFactory() - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClientFactory
 
D2HealthChecker - Class in com.linkedin.venice.d2
Runs a daemon thread that consistently sends HTTP GET request to admin healthcheck endpoint.
D2HealthChecker(ZooKeeperConnectionManager, long, String, int, ScheduledExecutorService, int) - Constructor for class com.linkedin.venice.d2.D2HealthChecker
 
d2Routing - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
D2Server - Class in com.linkedin.venice.d2
 
D2Server(D2ServerManager) - Constructor for class com.linkedin.venice.d2.D2Server
 
D2ServerManager - Class in com.linkedin.venice.d2
This class provides a server manager with start/shutdown methods to be invoked to manage the lifecycle of the server announcer.
D2ServerManager(ZooKeeperConnectionManager, long, boolean, long, boolean, boolean) - Constructor for class com.linkedin.venice.d2.D2ServerManager
 
D2ServerManager(ZooKeeperConnectionManager, long, boolean, long, boolean, boolean, boolean, boolean, boolean, long, int, String, ScheduledExecutorService, int) - Constructor for class com.linkedin.venice.d2.D2ServerManager
 
D2ServiceDiscovery - Class in com.linkedin.venice.client.store
This class is used to find the proper d2 service name for the given store through default D2 service d2://VeniceRouter.
D2ServiceDiscovery() - Constructor for class com.linkedin.venice.client.store.D2ServiceDiscovery
 
D2ServiceDiscovery(Time) - Constructor for class com.linkedin.venice.client.store.D2ServiceDiscovery
 
D2ServiceDiscoveryResponse - Class in com.linkedin.venice.controllerapi
 
D2ServiceDiscoveryResponse() - Constructor for class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
D2ServiceDiscoveryResponseV2 - Class in com.linkedin.venice.controllerapi
Deprecated.
D2ServiceDiscoveryResponseV2() - Constructor for class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponseV2
Deprecated.
 
D2TransportClient - Class in com.linkedin.venice.client.store.transport
D2Client based TransportClient implementation.
D2TransportClient(String, D2Client) - Constructor for class com.linkedin.venice.client.store.transport.D2TransportClient
Construct by an existing D2Client (such as from the pegasus-d2-client-default-cmpt).
D2TransportClient(String, ClientConfig) - Constructor for class com.linkedin.venice.client.store.transport.D2TransportClient
Construct by customized zookeeper and other configs.
DA_VINCI_CLIENT_BASED_METADATA - com.linkedin.venice.fastclient.meta.StoreMetadataFetchMode
Use da-vinci-client to query the locally materialized meta system store.
daemonThreadFactory() - Static method in enum com.linkedin.alpini.base.concurrency.Executors
 
DaemonThreadFactory - Class in com.linkedin.venice.utils
A thread factory that sets the threads to run as daemons.
DaemonThreadFactory(String) - Constructor for class com.linkedin.venice.utils.DaemonThreadFactory
 
DARWIN - com.linkedin.alpini.jna.ThreadUtils.OsPlatform
 
data() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
Data() - Constructor for class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Data
 
DATA_BASE_PATH - Static variable in class com.linkedin.venice.ConfigKeys
 
DATA_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
 
DATA_RECOVERY - com.linkedin.venice.controllerapi.ControllerRoute
 
DATA_RECOVERY_COMPLETED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
DATA_RECOVERY_COMPLETED - com.linkedin.venice.pushmonitor.ExecutionStatus
 
DATA_RECOVERY_COMPLETED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
DATA_RECOVERY_COPY_ALL_VERSION_CONFIGS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
Whether or not to copy all version configs from the source fabric when performing data recovery in a destination fabric.
DATA_REPLICATION_POLICY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
DATA_WRITER_COMPLETED - com.linkedin.venice.status.PushJobDetailsStatus
 
DATA_WRITER_COMPUTE_JOB_CLASS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config to set the class for the DataWriter job.
DATA_WRITER_JOB_COMPLETED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
dataAccessor - Variable in class com.linkedin.venice.helix.HelixStoreGraveyard
 
databaseInfo - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
A map of string -> string to store database related info, which is necessary to checkpoint
databaseSyncBytesIntervalForDeferredWriteMode - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Message bytes consuming interval before persisting offset in offset db for deferred-write database.
databaseSyncBytesIntervalForTransactionalMode - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Message bytes consuming interval before persisting offset in offset db for transactional mode database.
datagramChannel() - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
datagramChannel() - Method in enum com.linkedin.alpini.netty4.misc.NettyUtils.Mode
 
dataModel() - Method in interface com.linkedin.venice.meta.DataModelBackedStructure
Return the backed data model.
dataModel() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
dataModel() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
dataModel() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
dataModel() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
dataModel() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
dataModel() - Method in class com.linkedin.venice.meta.ReadOnlyViewConfig
 
dataModel() - Method in class com.linkedin.venice.meta.StoreConfig
 
dataModel() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
dataModel() - Method in class com.linkedin.venice.meta.VersionImpl
 
dataModel() - Method in class com.linkedin.venice.meta.ViewConfigImpl
 
dataModel() - Method in class com.linkedin.venice.meta.ZKStore
 
DataModelBackedStructure<T extends org.apache.avro.specific.SpecificRecord> - Interface in com.linkedin.venice.meta
 
DataProviderUtils - Class in com.linkedin.venice.utils
This class gathers all common data provider patterns in test cases.
DataProviderUtils() - Constructor for class com.linkedin.venice.utils.DataProviderUtils
 
dataRecovery(Admin) - Method in class com.linkedin.venice.controller.server.DataRecoveryRoutes
 
dataRecovery(String, String, String, int, boolean, boolean, Optional<Version>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
DataRecoveryClient - Class in com.linkedin.venice.datarecovery
DataRecoveryClient is the central class to manage data recovery feature.
DataRecoveryClient() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryClient
 
DataRecoveryClient(DataRecoveryExecutor, DataRecoveryMonitor, DataRecoveryEstimator) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryClient
 
DataRecoveryClient.DataRecoveryParams - Class in com.linkedin.venice.datarecovery
 
dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
dataRecoveryCompleted(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
dataRecoveryConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Properties related to data recovery mode behavior for this version.
DataRecoveryConfig - Class in com.linkedin.venice.systemstore.schemas
 
DataRecoveryConfig() - Constructor for class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Default constructor.
DataRecoveryConfig(CharSequence, Boolean, Integer) - Constructor for class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
All-args constructor.
DataRecoveryEstimator - Class in com.linkedin.venice.datarecovery
DataRecoveryExecutor is the engine to run tasks in data recovery.
DataRecoveryEstimator() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryEstimator
 
DataRecoveryExecutor - Class in com.linkedin.venice.datarecovery
DataRecoveryExecutor is the engine to run tasks in data recovery.
DataRecoveryExecutor() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryExecutor
 
DataRecoveryManager - Class in com.linkedin.venice.controller.datarecovery
This class contains all the logics to: 1.
DataRecoveryManager(VeniceHelixAdmin, D2Client, String, Optional<ICProvider>, PubSubTopicRepository) - Constructor for class com.linkedin.venice.controller.datarecovery.DataRecoveryManager
 
DataRecoveryMonitor - Class in com.linkedin.venice.datarecovery
 
DataRecoveryMonitor() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryMonitor
 
DataRecoveryParams(Set<String>) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryClient.DataRecoveryParams
 
DataRecoveryRoutes - Class in com.linkedin.venice.controller.server
 
DataRecoveryRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.DataRecoveryRoutes
 
dataRecoverySourceFabric - Variable in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
The fabric name to be used as the source for data recovery.
dataRecoverySourceVersionNumber - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
dataRecoverySourceVersionNumber - Variable in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
The store version number to be used as the source for data recovery.
DataRecoveryTask - Class in com.linkedin.venice.datarecovery
A Task is wrapper class that designed to execute multiple commands in sequence.
DataRecoveryTask(Command, DataRecoveryTask.TaskParams) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryTask
 
DataRecoveryTask.TaskParams - Class in com.linkedin.venice.datarecovery
 
DataRecoveryTask.TaskResult - Class in com.linkedin.venice.datarecovery
 
DataRecoveryVersionConfig - Interface in com.linkedin.venice.meta
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
DataRecoveryVersionConfigImpl - Class in com.linkedin.venice.meta
 
DataRecoveryVersionConfigImpl(String, boolean, int) - Constructor for class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
DataRecoveryWorker - Class in com.linkedin.venice.datarecovery
 
DataRecoveryWorker() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
DataRecoveryWorker(int) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
dataReplicationPolicy - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Real-time Samza job data replication policy.
dataReplicationPolicy - Variable in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Real-time Samza job data replication policy, and default is 'NON_AGGREGATE'
DataReplicationPolicy - Enum in com.linkedin.venice.meta
Enums of the policies used to decide how real-time samza data is replicated.
DATASET_CHANGED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
dataSource - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
DataValidationException - Exception in com.linkedin.venice.exceptions.validation
This class encompasses all error conditions which are related to the quality of the data consumed from Kafka.
DataValidationException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.DataValidationException
 
DataValidationException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.validation.DataValidationException
 
DataWriterAccumulators - Class in com.linkedin.venice.hadoop.spark.datawriter.task
All the AccumulatorV2 objects that are used in the Spark DataWriter jobs.
DataWriterAccumulators(SparkSession) - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
DataWriterComputeJob - Class in com.linkedin.venice.hadoop.jobs
An abstraction for executing and monitoring a data writer compute job running on any batch compute engine
DataWriterComputeJob() - Constructor for class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
dataWriterComputeJobClass - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
DataWriterMRJob - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.jobs
The implementation of DataWriterComputeJob for MapReduce engine.
DataWriterMRJob() - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
DataWriterSparkJob - Class in com.linkedin.venice.hadoop.spark.datawriter.jobs
The default implementation of AbstractDataWriterSparkJob for Avro and Vson file input formats.
DataWriterSparkJob() - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.jobs.DataWriterSparkJob
 
DataWriterTaskTracker - Interface in com.linkedin.venice.hadoop.task.datawriter
An interface to report and retrieve metrics related to data writer tasks.
DATE - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
DATETIME - com.linkedin.venice.Arg
 
DateUtils - Enum in com.linkedin.alpini.base.misc
 
DAVINCI_PUSH_STATUS_SCAN_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
DAVINCI_PUSH_STATUS_SCAN_INTERVAL_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
 
DAVINCI_PUSH_STATUS_SCAN_MAX_OFFLINE_INSTANCE_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
 
DAVINCI_PUSH_STATUS_SCAN_MAX_OFFLINE_INSTANCE_RATIO - Static variable in class com.linkedin.venice.ConfigKeys
 
DAVINCI_PUSH_STATUS_SCAN_NO_REPORT_RETRY_MAX_ATTEMPTS - Static variable in class com.linkedin.venice.ConfigKeys
Max retry when not receiving any DaVinci status report.
DAVINCI_PUSH_STATUS_SCAN_THREAD_NUMBER - Static variable in class com.linkedin.venice.ConfigKeys
 
DAVINCI_PUSH_STATUS_STORE - com.linkedin.venice.common.VeniceSystemStoreType
 
DAVINCI_PUSH_STATUS_STORE_STR - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
DaVinciBackend - Class in com.linkedin.davinci
 
DaVinciBackend(ClientConfig, VeniceConfigLoader, Optional<Set<String>>, ICProvider, Optional<ObjectCacheConfig>, Function<Integer, DaVinciRecordTransformer>) - Constructor for class com.linkedin.davinci.DaVinciBackend
 
DaVinciClient<K,​V> - Interface in com.linkedin.davinci.client
Da Vinci Client to provide key-value lookups in embedded mode
DaVinciClientBasedMetadata - Class in com.linkedin.venice.fastclient.meta
Deprecated.
DaVinciClientBasedMetadata(ClientConfig, DaVinciClient<StoreMetaKey, StoreMetaValue>) - Constructor for class com.linkedin.venice.fastclient.meta.DaVinciClientBasedMetadata
Deprecated.
 
DaVinciClientFactory - Interface in com.linkedin.davinci.client.factory
 
DaVinciClientMetaStoreBasedRepository - Class in com.linkedin.davinci.repository
Deprecated.
DaVinciClientMetaStoreBasedRepository(ClientConfig, VeniceProperties, CachingDaVinciClientFactory, SchemaReader) - Constructor for class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
DaVinciConfig - Class in com.linkedin.davinci.client
 
DaVinciConfig() - Constructor for class com.linkedin.davinci.client.DaVinciConfig
 
daVinciConfigProvider() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
DaVinciIngestionBackend - Interface in com.linkedin.davinci.ingestion
 
daVinciPushStatusStoreEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
daVinciPushStatusStoreEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not davinci push status store is enabled.
DaVinciRecordTransformer<K,​V,​O> - Class in com.linkedin.davinci.client
This abstract class can be extended in order to transform records stored in the Da Vinci Client.
DaVinciRecordTransformer(int) - Constructor for class com.linkedin.davinci.client.DaVinciRecordTransformer
 
DEADLINE_EXCEEDED - Static variable in class com.linkedin.venice.grpc.GrpcErrorCodes
 
debug(CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Message) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
debug(Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
DEBUG - com.linkedin.venice.Arg
 
DEBUG - Static variable in class com.linkedin.alpini.consts.Level
The DEBUG Level designates fine-grained informational events that are most useful to debug an application.
DEBUG_INT - Static variable in class com.linkedin.alpini.consts.Level
 
debugInfo - Variable in class com.linkedin.venice.kafka.protocol.ControlMessage
This metadata is for logging and traceability purposes.
debugInfo - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The debug info received as part of the last StartOfSegment ControlMessage.
decode(Headers) - Method in interface com.linkedin.alpini.router.api.MetricsDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.compression.SnappyDecoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartDecode
 
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
decode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
decode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartAggregator
 
decode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.HttpContentUnwrap
 
decode(ChannelHandlerContext, Http2StreamFrame, List<Object>) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
decode(ChannelHandlerContext, I, List<Object>) - Method in class io.netty.handler.codec.EspressoMessageAggregator
 
decode(ChannelHandlerContext, I, List<Object>) - Method in class io.netty.handler.codec.EspressoMessageToMessageDecoder
Decode from one message to an other.
decode(AsciiString, Charset) - Static method in enum com.linkedin.alpini.netty4.misc.AsciiStringURLCodec
Decodes a application/x-www-form-urlencoded string using a specific encoding scheme.
decode(CharSequence, Charset) - Static method in enum com.linkedin.alpini.base.misc.URLCodec
Decodes a application/x-www-form-urlencoded string using a specific encoding scheme.
decode(String, Charset) - Static method in enum com.linkedin.alpini.base.misc.URLCodec
Decodes a application/x-www-form-urlencoded string using a specific encoding scheme.
decodeLast(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.compression.SnappyDecoder
 
decodeLast(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartDecode
 
decodeLast(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
Decoder(int, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
Creates a new instance with the specified parameters.
decodeStringAndConvertToVeniceChangeCoordinate(String) - Static method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
decodeTime(long) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
decompress(byte[], int, int) - Method in class com.linkedin.venice.compression.GzipCompressor
 
decompress(byte[], int, int) - Method in class com.linkedin.venice.compression.NoopCompressor
 
decompress(byte[], int, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
 
decompress(byte[], int, int) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
decompress(InputStream) - Method in class com.linkedin.venice.compression.GzipCompressor
 
decompress(InputStream) - Method in class com.linkedin.venice.compression.NoopCompressor
 
decompress(InputStream) - Method in class com.linkedin.venice.compression.VeniceCompressor
 
decompress(InputStream) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
decompress(ByteBuffer) - Method in class com.linkedin.venice.compression.GzipCompressor
 
decompress(ByteBuffer) - Method in class com.linkedin.venice.compression.NoopCompressor
 
decompress(ByteBuffer) - Method in class com.linkedin.venice.compression.VeniceCompressor
 
decompress(ByteBuffer) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
decompressAndDeserialize(RecordDeserializer<T>, VeniceCompressor, ByteBuffer) - Method in class com.linkedin.davinci.utils.ChunkAssembler
 
decompressAndPrependSchemaHeader(byte[], int, int, int) - Method in class com.linkedin.venice.compression.GzipCompressor
 
decompressAndPrependSchemaHeader(byte[], int, int, int) - Method in class com.linkedin.venice.compression.NoopCompressor
 
decompressAndPrependSchemaHeader(byte[], int, int, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
This method tries to decompress data and maybe prepend the schema header.
decompressAndPrependSchemaHeader(byte[], int, int, int) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
decompressMultiGetContent(CompressionStrategy, ByteBuf) - Method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
Decompressing multi-get response in router side is a bit of overhead.
decompressSingleGetContent(CompressionStrategy, ByteBuf) - Method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
 
decorate(Headers, Metrics) - Method in interface com.linkedin.alpini.router.api.MetricsDecorator
 
decorateName(ThreadFactory) - Static method in class com.linkedin.alpini.jna.ThreadUtils
 
decorateResponse(Headers, Headers, Metrics) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Modifies or replaces the task used to execute a runnable.
decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Modifies or replaces the task used to execute a callable.
decrementClientConnectionCount() - Method in class com.linkedin.venice.stats.ServerConnectionStats
 
decrementRouterConnectionCount() - Method in class com.linkedin.venice.stats.ServerConnectionStats
 
decrementThreadBlockedOnOfflineToDroppedTransitionCount() - Method in class com.linkedin.davinci.stats.ParticipantStateTransitionStats
 
deepCloneArray(V[]) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
Clones an array with arbitrary levels of nesting.
DeepCopyOffsetManager - Class in com.linkedin.venice.offsets
This class is used to systematically copy OffsetRecord instances rather than passing them as is.
DeepCopyOffsetManager(OffsetManager) - Constructor for class com.linkedin.venice.offsets.DeepCopyOffsetManager
 
DeepCopyStorageMetadataService - Class in com.linkedin.venice.offsets
This class is used to systematically copy OffsetRecord instances rather than passing them as is.
DeepCopyStorageMetadataService(StorageMetadataService) - Constructor for class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
 
DeepEqualsArrayList() - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
Deprecated.
 
DeepEqualsArrayList(int) - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
Deprecated.
 
DeepEqualsHashMap() - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsHashMap
Deprecated.
 
deepToStringObject(T...) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
DEFAULT_BATCH_BYTES_SIZE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_BATCH_GET_LIMIT - Static variable in interface com.linkedin.venice.meta.Store
 
DEFAULT_BITSET_SIZE - Static variable in class com.linkedin.venice.utils.RedundantExceptionFilter
 
DEFAULT_BLOCK_SIZE - Static variable in class com.linkedin.alpini.io.PigzOutputStream
 
DEFAULT_BUILDER - Static variable in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
DEFAULT_CHECK_SUM_TYPE - Static variable in class com.linkedin.venice.writer.VeniceWriter
Default checksum type.
DEFAULT_CHUNK_SPLIT_THRESHOLD - Static variable in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
DEFAULT_CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.venice.writer.VeniceWriter
This controls the Kafka producer's close timeout.
DEFAULT_CLUSTER_DISCOVERY_D2_SERVICE_NAME - Static variable in class com.linkedin.venice.client.store.ClientConfig
 
DEFAULT_COLUMN_FAMILY_INDEX - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
DEFAULT_COMPRESSION_DICTIONARY_SAMPLE_SIZE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_COMPRESSION_METRIC_COLLECTION_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_CONN_WARMUP_TIMEOUT_IN_SECONDS_DEFAULT - Static variable in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
DEFAULT_CONTROLLER_SSL_ENABLED - Static variable in class com.linkedin.venice.SSLConfig
 
DEFAULT_D2_ZK_BASE_PATH - Static variable in class com.linkedin.venice.client.store.ClientConfig
 
DEFAULT_DB_QUEUE - Static variable in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
DEFAULT_DOC - Static variable in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
Deprecated.
 
DEFAULT_EXTENDED_SCHEMA_VALIDITY_CHECK_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_FORMAT - Static variable in class com.linkedin.venice.RequestConstants
 
DEFAULT_GUID_GENERATOR_IMPLEMENTATION - Static variable in class com.linkedin.venice.guid.GuidUtils
 
DEFAULT_HELIX_OP_RETRY_COUNT - Static variable in class com.linkedin.venice.utils.HelixUtils
Retry 3 times for each helix operation in case of getting the error by default.
DEFAULT_HYBRID_OFFSET_LAG_THRESHOLD - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
DEFAULT_HYBRID_TIME_LAG_THRESHOLD - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
DEFAULT_INSTANCE_GROUP_ID - Static variable in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
DEFAULT_IS_DUPLICATED_KEY_ALLOWED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_JOB_STATUS_IN_UNKNOWN_STATE_TIMEOUT_MS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
The default total time we wait before failing a job if the job status stays in UNKNOWN state.
DEFAULT_KAFKA_BATCH_SIZE - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
Default Kafka batch size and linger time for better producer performance during ingestion.
DEFAULT_KAFKA_INPUT_MAX_RECORDS_PER_MAPPER - Static variable in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
The default max records per mapper, and if there are more records in one topic partition, it will be consumed by multiple mappers in parallel.
DEFAULT_KAFKA_LINGER_MS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
DEFAULT_KAFKA_MIN_LOG_COMPACTION_LAG_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
Default setting is that no log compaction should happen for hybrid store version topics if the messages are produced within 24 hours; otherwise servers could encounter MISSING data DIV errors for reprocessing jobs which could potentially generate lots of duplicate keys.
DEFAULT_KAFKA_REPLICATION_FACTOR - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
DEFAULT_KEY_FIELD_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_LEADER_METADATA_WRAPPER - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
DEFAULT_MAX_ATTEMPTS_WHEN_TOPIC_MISSING - Static variable in class com.linkedin.venice.writer.VeniceWriter
Default number of attempts when trying to produce to a Kafka topic and an exception is caught saying the topic is missing.
DEFAULT_MAX_CONCURRENT_STREAMS - Static variable in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
DEFAULT_MAX_MESSAGES - Static variable in class com.linkedin.alpini.base.misc.TouchTimer
Default maximum number of messages allowed on one timer.
DEFAULT_MAX_NUMBER_OF_PARTITIONS - Static variable in class com.linkedin.venice.ConfigKeys
 
DEFAULT_MAX_REUSE_STREAM_CHANNELS_LIMIT - Static variable in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
DEFAULT_MAX_SIZE_FOR_USER_PAYLOAD_PER_MESSAGE_IN_BYTES - Static variable in class com.linkedin.venice.writer.VeniceWriter
950 KB for user payload should be conservative enough.
DEFAULT_MESSAGE - Static variable in exception com.linkedin.alpini.base.misc.Http2TooManyStreamsException
 
DEFAULT_NAMESPACE - Static variable in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
Deprecated.
 
DEFAULT_NO_REDUNDANT_EXCEPTION_DURATION_MS - Static variable in class com.linkedin.venice.utils.RedundantExceptionFilter
 
DEFAULT_NUMBER_OF_PARTITION - Static variable in class com.linkedin.venice.ConfigKeys
 
DEFAULT_NUMBER_OF_PARTITION_FOR_HYBRID - Static variable in class com.linkedin.venice.ConfigKeys
 
DEFAULT_OFFLINE_PUSH_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
 
DEFAULT_OFFSET_LAG - Static variable in class com.linkedin.venice.offsets.OffsetRecord
 
DEFAULT_PARTITION_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
 
DEFAULT_PER_ROUTER_READ_QUOTA - Static variable in class com.linkedin.venice.VeniceConstants
Default per router max read quota; notice that this value is used in controller; the actual per router max read quota is defined as a router config "max.read.capacity".
DEFAULT_POLL_STATUS_INTERVAL_MS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_RE_PUSH_REWIND_IN_SECONDS_OVERRIDE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
The rewind override when performing re-push to prevent data loss; if the store has higher rewind config setting than 1 days, adopt the store config instead; otherwise, override the rewind config to 1 day if push job config doesn't try to override it.
DEFAULT_READ_QUOTA - Static variable in class com.linkedin.venice.meta.AbstractStore
Default read quota 1800 QPS per node
DEFAULT_READ_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
Fallback to remain compatible with the old config spelling.
DEFAULT_RECEIVE_BUFFER_SIZE - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
DEFAULT_REFRESH_INTERVAL_IN_SECONDS - Static variable in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
DEFAULT_REPAIR_THREAD_SLEEP_INTERVAL_SECONDS - Static variable in class com.linkedin.davinci.kafka.consumer.RemoteIngestionRepairService
 
DEFAULT_REPLICA_FACTOR - Static variable in class com.linkedin.venice.ConfigKeys
 
DEFAULT_REPLICATION_FACTOR - Static variable in class com.linkedin.venice.meta.AbstractStore
 
DEFAULT_REPORTER_THREAD_SLEEP_INTERVAL_SECONDS - Static variable in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
DEFAULT_RETRY_LOAD_ATTEMPTS - Static variable in class com.linkedin.venice.helix.CachedResourceZkStateListener
 
DEFAULT_RETRY_LOAD_INTERVAL_IN_MS - Static variable in class com.linkedin.venice.helix.CachedResourceZkStateListener
 
DEFAULT_REWIND_TIME_IN_SECONDS - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
DEFAULT_ROUTING_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
 
DEFAULT_RT_RETENTION_TIME - Static variable in interface com.linkedin.venice.meta.Store
 
DEFAULT_SCHEMA - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
DEFAULT_SCHEMA_CREATION_COMPATIBILITY_TYPE - Static variable in class com.linkedin.venice.schema.SchemaEntry
 
DEFAULT_SCHEMA_REFRESH_PERIOD - Static variable in class com.linkedin.venice.client.store.ClientConfig
 
DEFAULT_SCHEMA_WITH_PARTITION - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
DEFAULT_SEND_MESSAGE_TIME_OUT - Static variable in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
DEFAULT_SERVER_KAFKA_FETCH_QUOTA_RECORDS_PER_SECOND - Static variable in class com.linkedin.venice.meta.LiveClusterConfig
 
DEFAULT_SLEEP_TIME_MS_WHEN_TOPIC_MISSING - Static variable in class com.linkedin.venice.writer.VeniceWriter
Sleep time in between retry attempts when a topic is missing.
DEFAULT_SPARK_CLUSTER - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
DEFAULT_SSL_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_SSL_FACTORY_CLASS_NAME - Static variable in class com.linkedin.venice.VeniceConstants
The default SSL factory class name; this class is mostly used in test cases; products that uses Venice lib should override the SSL factory class.
DEFAULT_STORAGE_QUOTA - Static variable in class com.linkedin.venice.meta.AbstractStore
Default storage quota 20GB
DEFAULT_STORE_QUOTA_TIME_WINDOW - Static variable in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
DEFAULT_TOPIC_RETENTION_POLICY_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
DEFAULT_UPSTREAM_KAFKA_CLUSTER_ID - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
DEFAULT_UPSTREAM_OFFSET - Static variable in class com.linkedin.venice.writer.VeniceWriter
The default value of the "upstreamOffset" field in avro record LeaderMetadata.
DEFAULT_USE_MAPPER_TO_BUILD_DICTIONARY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_USER_DATA_RECORD_COUNT - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
DEFAULT_USER_DATA_VALUE_PREFIX - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
DEFAULT_USER_SYSTEM_STORE_UPDATE_QUERY_PARAMS - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
DEFAULT_VALUE_FIELD_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DEFAULT_ZK_TIMEOUT_MS - Static variable in class com.linkedin.venice.client.store.ClientConfig
 
DefaultAsyncFuture<T> - Class in com.linkedin.alpini.base.concurrency.impl
An implementation of AsyncFuture where much of the implementation is based upon netty's org.jboss.netty.channel.DefaultChannelFuture.
DefaultAsyncFuture(boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
Creates a new instance.
DefaultAsyncFutureTask<T> - Class in com.linkedin.alpini.base.concurrency.impl
Wraps a Callable in a FutureTask and make it notify a DefaultAsyncFuture.
DefaultAsyncFutureTask(Callable<T>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
Wrap a callable in an AsyncFuture.
DefaultAsyncFutureTask(Executor, Callable<T>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
 
DefaultAsyncFutureTask(ExecutorService, Callable<T>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
Wrap a callable in an AsyncFuture and then submit it to be executed on the provided ExecutorService.
DefaultCollectingAsyncFuture<V> - Class in com.linkedin.alpini.base.concurrency.impl
A specialised instance of @{link AsyncFuture} for collecting the results of one or more futures of lists into a single list.
DefaultCollectingAsyncFuture(List<AsyncFuture<List<V>>>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultCollectingAsyncFuture
Creates a new instance.
DefaultCollectingAsyncFuture(List<AsyncFuture<List<V>>>, boolean, Function<List<V>, List<V>>) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultCollectingAsyncFuture
Creates a new instance.
defaultFactory() - Static method in class org.apache.avro.io.OptimizedBinaryDecoderFactory
 
DefaultFileChannelHttpResponse - Class in com.linkedin.alpini.netty4.misc
 
DefaultFileChannelHttpResponse(HttpVersion, HttpResponseStatus, boolean, boolean, ByteBufAllocator, FileChannel) - Constructor for class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
defaultGenericClientConfig(String) - Static method in class com.linkedin.venice.client.store.ClientConfig
 
DefaultHadoopJobClientProvider - Class in com.linkedin.venice.hadoop.mapreduce.engine
 
DefaultHadoopJobClientProvider() - Constructor for class com.linkedin.venice.hadoop.mapreduce.engine.DefaultHadoopJobClientProvider
 
DefaultIdentityParser - Class in com.linkedin.venice.authorization
 
DefaultIdentityParser() - Constructor for class com.linkedin.venice.authorization.DefaultIdentityParser
 
DefaultIngestionBackend - Class in com.linkedin.davinci.ingestion
The default ingestion backend implementation.
DefaultIngestionBackend(StorageMetadataService, KafkaStoreIngestionService, StorageService) - Constructor for class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
DefaultInputDataInfoProvider - Class in com.linkedin.venice.hadoop
 
DefaultInputDataInfoProvider(PushJobSetting, VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
DefaultJobClientWrapper - Class in com.linkedin.venice.hadoop.mapreduce.engine
 
DefaultJobClientWrapper() - Constructor for class com.linkedin.venice.hadoop.mapreduce.engine.DefaultJobClientWrapper
 
DefaultLingeringStoreVersionChecker - Class in com.linkedin.venice.controller.lingeringjob
 
DefaultLingeringStoreVersionChecker() - Constructor for class com.linkedin.venice.controller.lingeringjob.DefaultLingeringStoreVersionChecker
 
defaultMode - Static variable in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
 
defaultMode - Static variable in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
DefaultPushJobHeartbeatSenderFactory - Class in com.linkedin.venice.hadoop.heartbeat
 
DefaultPushJobHeartbeatSenderFactory() - Constructor for class com.linkedin.venice.hadoop.heartbeat.DefaultPushJobHeartbeatSenderFactory
 
defaultReadyToServeChecker - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
DefaultSerializer - Class in com.linkedin.venice.serialization
Default Kafka VeniceKafkaSerializer
DefaultSerializer() - Constructor for class com.linkedin.venice.serialization.DefaultSerializer
 
defaultSpecificClientConfig(String, Class<V>) - Static method in class com.linkedin.venice.client.store.ClientConfig
 
DefaultSSLFactory - Class in com.linkedin.venice.security
Cloned from com.linkedin.security.ssl.access.control.SSLEngineComponentFactoryImpl; Changes: 1.
DefaultSSLFactory(SSLConfig) - Constructor for class com.linkedin.venice.security.DefaultSSLFactory
 
DefaultSSLFactory(Properties) - Constructor for class com.linkedin.venice.security.DefaultSSLFactory
 
DefaultSupersetSchemaGenerator - Class in com.linkedin.venice.controller.supersetschema
 
DefaultSupersetSchemaGenerator() - Constructor for class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
 
defaultThreadFactory() - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a default thread factory used to create new threads.
defaultTimeoutMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
defaultValue() - Method in annotation type com.linkedin.alpini.cli.CLIArgument
Default value for the option.
DefaultVenicePartitioner - Class in com.linkedin.venice.partitioner
Default implementation of the VenicePartitioner class.
DefaultVenicePartitioner() - Constructor for class com.linkedin.venice.partitioner.DefaultVenicePartitioner
 
DefaultVenicePartitioner(VeniceProperties) - Constructor for class com.linkedin.venice.partitioner.DefaultVenicePartitioner
 
DefaultVenicePartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.partitioner.DefaultVenicePartitioner
 
defaultVPJProps(String, String, String) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
defaultVPJPropsWithD2Routing(String, String, Map<String, String>, String, String, String, String) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
defaultVsonGenericClientConfig(String) - Static method in class com.linkedin.venice.client.store.ClientConfig
Deprecated.
DEFER_VERSION_SWAP - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
DEFER_VERSION_SWAP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
This config is a boolean which waits for an external signal to trigger version swap after buffer replay is complete.
deferred(boolean) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Create a new default deferred future.
deferredWrite - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
Whether the input is sorted or not.
deferredWrite - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether deferred write mode is enabled currently
deferVersionSwap - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
deferVersionSwap - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
flag that informs venice controller to defer marking this version as the serving version after instances report ready to serve.
definition - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
deflate() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
deflate() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
DEFLATE - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
DEGRADED - com.linkedin.venice.meta.StoreStatus
 
DELAY_EXECUTION - Static variable in class com.linkedin.venice.RequestConstants
 
DELAY_TO_REBALANCE_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
delayFactor - Variable in class com.linkedin.venice.controller.kafka.TopicCleanupService
 
delegateConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
delegateConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
The goal of this function is to possibly produce the incoming kafka message consumed from local VT, remote VT, RT or SR topic to local VT if needed.
delegateConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
DelegatingAvroGenericDaVinciClient<K,​V> - Class in com.linkedin.davinci.client
Delegating layer for DaVinciClient.
DelegatingAvroGenericDaVinciClient(AvroGenericDaVinciClient<K, V>) - Constructor for class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
DelegatingAvroStoreClient<K,​V> - Class in com.linkedin.venice.fastclient
Inside Fast-Client, we choose to use n-tier architecture style to build a pipeline to separate different types of logic in different layer.
DelegatingAvroStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
DelegatingClusterLeaderInitializationRoutine - Class in com.linkedin.venice.controller.init
 
DelegatingClusterLeaderInitializationRoutine() - Constructor for class com.linkedin.venice.controller.init.DelegatingClusterLeaderInitializationRoutine
 
DelegatingStoreClient<K,​V> - Class in com.linkedin.venice.client.store
 
DelegatingStoreClient(InternalAvroStoreClient<K, V>) - Constructor for class com.linkedin.venice.client.store.DelegatingStoreClient
 
DelegatingTrackingCallback<K,​V> - Class in com.linkedin.venice.client.store.streaming
 
DelegatingTrackingCallback(StreamingCallback<K, V>) - Constructor for class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
 
delete() - Method in class com.linkedin.davinci.config.StoreBackendConfig
 
delete(byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Delete a key from the partition database
delete(byte[]) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
delete(byte[]) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
delete(byte[]) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
delete(byte[]) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
delete(int, byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
delete(ValueAndRmd<ByteBuffer>, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeByteBuffer
 
delete(ValueAndRmd<GenericRecord>, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeGenericRecord
 
delete(ValueAndRmd<T>, long, int, long, int) - Method in interface com.linkedin.davinci.replication.merge.Merge
 
delete(KafkaKey, KafkaMessageEnvelope, PubSubProducerCallback, int, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
DIV pass-through mode for delete
delete(Lazy<ByteBuffer>, RmdWithValueSchemaId, long, long, int, int) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolver
Perform conflict resolution when the incoming operation is a DELETE operation.
delete(Lazy<K>) - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
By default, deletes will proceed.
delete(Object) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
delete(K, long, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "delete" on the key.
delete(K, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "delete" on the key.
delete(K, PubSubProducerCallback, DeleteMetadata) - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
delete(K, PubSubProducerCallback, DeleteMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
 
delete(K, PubSubProducerCallback, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "delete" on the key.
delete(K, PubSubProducerCallback, LeaderMetadataWrapper, long) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "delete" on the key.
delete(K, PubSubProducerCallback, LeaderMetadataWrapper, long, DeleteMetadata, ChunkedValueManifest, ChunkedValueManifest) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "delete" on the key.
delete(K, PubSubProducerCallback, LeaderMetadataWrapper, DeleteMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "delete" on the key.
Delete - Class in com.linkedin.venice.kafka.protocol
Delete payloads contain fields related to replication metadata of the record.
Delete() - Constructor for class com.linkedin.venice.kafka.protocol.Delete
Default constructor.
Delete(Integer, Integer, ByteBuffer) - Constructor for class com.linkedin.venice.kafka.protocol.Delete
All-args constructor.
DELETE - com.linkedin.venice.authorization.Method
 
DELETE - com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
 
DELETE - com.linkedin.venice.kafka.protocol.enums.MessageType
 
DELETE_ACL - com.linkedin.venice.controllerapi.ControllerRoute
 
DELETE_ALL_VERSIONS - com.linkedin.venice.Command
 
DELETE_ALL_VERSIONS - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DELETE_ALL_VERSIONS - com.linkedin.venice.controllerapi.ControllerRoute
 
DELETE_KAFKA_TOPIC - com.linkedin.venice.Command
 
DELETE_KAFKA_TOPIC - com.linkedin.venice.controllerapi.ControllerRoute
 
DELETE_OLD_VERSION - com.linkedin.venice.Command
 
DELETE_OLD_VERSION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DELETE_OLD_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
DELETE_ON_NEW_PUSH_START - com.linkedin.venice.meta.BackupStrategy
Delete versions on SN (including kafka and metadata) to preserve only (numVersionsToPreserve-1) backup versions on new push start.
DELETE_STORAGE_PERSONA - com.linkedin.venice.Command
 
DELETE_STORAGE_PERSONA - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DELETE_STORAGE_PERSONA - com.linkedin.venice.controllerapi.ControllerRoute
 
DELETE_STORE - com.linkedin.venice.Command
 
DELETE_STORE - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DELETE_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
DELETE_STORE_ACL - com.linkedin.venice.Command
 
DELETE_UNUSED_VALUE_SCHEMA - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DELETE_UNUSED_VALUE_SCHEMAS - com.linkedin.venice.controllerapi.ControllerRoute
 
deleteAclForStore(Admin) - Method in class com.linkedin.venice.controller.server.CreateStore
 
deleteAclForStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
deleteAclForStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
Delete the current set of ACL provisioned for a venice store and its associated kafka topic.
deleteAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
deleteAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
deleteAllVersions(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
deleteAllVersions(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
DeleteAllVersions - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
DeleteAllVersions() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
Default constructor.
DeleteAllVersions(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
All-args constructor.
deleteAllVersionsInStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
Delete all of venice versions in given store(including venice resource, kafka topic, offline pushs and all related resources).
deleteAllVersionsInStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
deleteAllVersionsInStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
deleteConfig(String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
deleteConfigs() - Method in class com.linkedin.venice.helix.HelixReadWriteLiveClusterConfigRepository
 
deleteConfigs() - Method in interface com.linkedin.venice.meta.ReadWriteLiveClusterConfigRepository
Delete all live cluster configs
DELETED_ELEM_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
DELETED_ELEM_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
DELETED_ELEM_TS_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
DELETED_ELEM_TS_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
DELETED_TS - Variable in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
If the current record is a PUT, this field will be null; if it's a DELETE, this field will be the offset of the record in Kafka
deleteDeprecatedChunk(byte[], int, PubSubProducerCallback, LeaderMetadataWrapper, DeleteMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
This method produces a DELETE request to a deprecated chunk key.
deleteDirectory(File) - Static method in class com.linkedin.venice.utils.TestUtils
 
deleteFilesInDirectory(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
deleteHelixResource(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
deleteHelixResource(String, String) - Method in interface com.linkedin.venice.meta.StoreCleaner
This purpose of the function is to delete the given resource from the Helix cluster.
deleteKafkaTopic(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
deleteKafkaTopic(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
DeleteMetadata - Class in com.linkedin.venice.writer
This is a simple container class to hold replication metadata related fields together to be passed on to the Delete api in VeniceWriter VeniceWriter#delete(Object, Callback, LeaderMetadataWrapper, long, Optional).
DeleteMetadata(int, int, ByteBuffer) - Constructor for class com.linkedin.venice.writer.DeleteMetadata
 
deleteOfflinePushStatusAndItsPartitionStatuses(String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
deleteOfflinePushStatusAndItsPartitionStatuses(String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Delete offline push and its partition statuses from persistent storage.
deleteOldVersion(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
DeleteOldVersion - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
DeleteOldVersion() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
Default constructor.
DeleteOldVersion(CharSequence, CharSequence, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
All-args constructor.
deleteOldVersionInStore(String, String, int) - Method in interface com.linkedin.venice.controller.Admin
Delete the given version from the store.
deleteOldVersionInStore(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
deleteOldVersionInStore(String, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
deleteOldVersions(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
deleteOneStoreVersion(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Delete version from cluster, removing all related resources
deleteOneStoreVersion(String, String, int) - Method in interface com.linkedin.venice.meta.StoreCleaner
 
deleteParticipantStoreKillMessage(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Compose a ParticipantMessageKey message and execute a delete operation on the key to the cluster's participant store.
deletePartitionIncrementalPushStatus(String, int, String, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
N.B.: Currently used by tests only.
deletePersona(StoragePersona) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
 
deletePersona(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
Deletes the persona with the given name.
deletePersona(String) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
 
deletePushStatus(String, int, Optional<String>, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
deleteRecord(GenericRecord, GenericRecord, long, int) - Method in interface com.linkedin.davinci.schema.merge.MergeRecordHelper
 
deleteRecordField(GenericRecord, GenericRecord, Schema.Field, long, int) - Method in class com.linkedin.davinci.schema.merge.CollectionTimestampMergeRecordHelper
 
deleteReplicaStatus(HelixPartitionState, String, String) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
 
deleteReplicaStatus(String, int) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
When a replica is gone from an instance due to partition movement or resource drop, we need to call this delete function to explicitly delete the customized state for that replica.
deleteStoragePersona(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
 
deleteStoragePersona(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
deleteStoragePersona(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
deleteStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
deleteStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Deletes the persona with the given name.
DeleteStoragePersona - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
DeleteStoragePersona() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
Default constructor.
DeleteStoragePersona(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
All-args constructor.
deleteStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
deleteStore(String) - Method in class com.linkedin.davinci.DaVinciBackend
 
deleteStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
deleteStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
deleteStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepositoryAdapter
This function only be used to delete regular venice store, and the system store is bundled with regular venice store.
deleteStore(String) - Method in interface com.linkedin.venice.meta.ReadWriteStoreRepository
Delete store from repository.
deleteStore(String, String, int, boolean) - Method in interface com.linkedin.venice.controller.Admin
Delete the entire store including both metadata and real user's data.
deleteStore(String, String, int, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
This method will delete store data, metadata, version and rt topics One exception is for stores with isMigrating flag set.
deleteStore(String, String, int, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Delete a store by sending DELETE_STORE admin message to the Kafka admin topic and clearing all ACLs and release resource for the target store from authorize service.
DeleteStore - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
DeleteStore() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
Default constructor.
DeleteStore(CharSequence, CharSequence, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
All-args constructor.
deleteStoreReplicaStatus(String, String, int, int) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
Clean up deprecated replica statuses.
deleteSystemStore(VeniceHelixAdmin, ReadWriteStoreRepository, PushMonitorDelegator, String, String, boolean, MetaStoreWriter, Logger) - Static method in class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
 
deleteTopic(PubSubTopic, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Delete a given topic.
deleteTopic(PubSubTopic, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Delete a given topic.
deleteTopic(PubSubTopic, Duration) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
DeleteUnusedValueSchemas - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
DeleteUnusedValueSchemas() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
Default constructor.
DeleteUnusedValueSchemas(CharSequence, CharSequence, List<Integer>) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
All-args constructor.
deleteValueSchema(SchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
 
deleteValueSchemas(String, String, Set<Integer>) - Method in interface com.linkedin.venice.controller.Admin
Deletes a store's values schema with ids `except` the ids passed in the argument inuseValueSchemaIds
deleteValueSchemas(String, String, Set<Integer>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
deleteValueSchemas(String, String, Set<Integer>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
deleteValueSchemas(String, List<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
deleteVersion(int) - Method in class com.linkedin.venice.meta.AbstractStore
 
deleteVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
deleteVersion(int) - Method in interface com.linkedin.venice.meta.Store
 
deleteWithReplicationMetadata(byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
This API deletes a record from RocksDB but updates the metadata in ByteBuffer format and puts it into RocksDB.
deleteWithReplicationMetadata(byte[], byte[]) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
This API deletes a record from RocksDB but updates the metadata in ByteBuffer format and puts it into RocksDB.
deleteWithReplicationMetadata(int, byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
deleting - Variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Is the store undergoing deletion.
DELIMITER - Static variable in class com.linkedin.venice.stats.AbstractVeniceStats
 
Delta() - Constructor for class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
DEMOTE_TO_STANDBY - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
demoteToStandby(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
demoteToStandby(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
demoteToStandby(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in interface com.linkedin.davinci.ingestion.VeniceIngestionBackend
 
demoteToStandby(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
demoteToStandby(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
 
demoteToStandby(PubSubTopicPartition, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
demoteToStandby(PubSubTopicPartition, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
demoteToStandby(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
DENY - com.linkedin.venice.authorization.Permission
 
DEPLOYMENT_ID - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
DEPRECATED_TOPIC_MAX_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is to indicate the max retention policy we have setup for deprecated jobs currently and in the past.
DEPRECATED_TOPIC_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
The retention policy for deprecated topics, which includes topics for both failed jobs and retired store versions.
dequalifyClassName(String) - Static method in class com.linkedin.venice.utils.TestUtils
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
deregister(ChannelHandlerContext, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
deregisterPartition(String) - Method in class com.linkedin.davinci.stats.RocksDBMemoryStats
 
DERIVED_SCHEMA - com.linkedin.venice.Arg
 
DERIVED_SCHEMA - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
DERIVED_SCHEMA_CREATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DERIVED_SCHEMA_ID - com.linkedin.venice.Arg
 
DERIVED_SCHEMA_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
DERIVED_SCHEMA_ID_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
DerivedMutableByteBuf - Class in com.linkedin.alpini.base.safealloc
Mutable ByteBuf.
DerivedMutableByteBuf(ByteBuf) - Constructor for class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
DerivedMutableByteBuf(ByteBuf, int, int) - Constructor for class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
DerivedReadOnlyByteBuf - Class in com.linkedin.alpini.base.safealloc
Immutable ByteBuf.
DerivedReadOnlyByteBuf(ByteBuf) - Constructor for class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
DerivedReadOnlyByteBuf(ByteBuf, int, int) - Constructor for class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
DerivedSchemaCreation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
DerivedSchemaCreation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Default constructor.
DerivedSchemaCreation(CharSequence, CharSequence, SchemaMeta, Integer, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
All-args constructor.
DerivedSchemaEntry - Class in com.linkedin.venice.schema.writecompute
Derived schemas are designed for write compute operations.
DerivedSchemaEntry(int, int, byte[]) - Constructor for class com.linkedin.venice.schema.writecompute.DerivedSchemaEntry
 
DerivedSchemaEntry(int, int, String) - Constructor for class com.linkedin.venice.schema.writecompute.DerivedSchemaEntry
 
DerivedSchemaEntry(int, int, Schema) - Constructor for class com.linkedin.venice.schema.writecompute.DerivedSchemaEntry
 
DerivedSchemaEntrySerializer - Class in com.linkedin.venice.helix
This class is registered in ZKClient to handle derive schema serialization.
DerivedSchemaEntrySerializer() - Constructor for class com.linkedin.venice.helix.DerivedSchemaEntrySerializer
 
derivedSchemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
derivedSchemaId - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
descendingIterator() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Returns an iterator over the elements in reverse sequential order.
DESCRIBE_STORE - com.linkedin.venice.Command
 
DESCRIBE_STORES - com.linkedin.venice.Command
 
describeAcls(Resource) - Method in interface com.linkedin.venice.authorization.AuthorizerService
Return a list of existing AceEntries present for the given resource.
describeAcls(Resource) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
description() - Method in annotation type com.linkedin.alpini.cli.CLIArgument
A short sentence description of the option.
description() - Method in annotation type com.linkedin.alpini.cli.CLIFlag
A short sentence description of the option.
deserializationExecutor - Variable in class com.linkedin.venice.client.store.deserialization.BatchDeserializer
 
deserialize(byte[]) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
 
deserialize(byte[]) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserialize(byte[]) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserialize(byte[]) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserialize(byte[], int) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
deserialize(byte[], int, SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.controller.kafka.consumer.StringToLongMapJSONSerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.controller.migration.MigrationPushStrategyJSONSerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.helix.AbstractSchemaEntrySerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.helix.HelixAdapterSerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.helix.SchemaEntrySerializer
This function will extract schema from file path, and schema content from ZNode data.
deserialize(byte[], String) - Method in class com.linkedin.venice.helix.StoreJSONSerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.helix.SystemStoreJSONSerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.helix.VeniceJsonSerializer
 
deserialize(byte[], String) - Method in class com.linkedin.venice.meta.SimpleStringSerializer
 
deserialize(byte[], String) - Method in interface com.linkedin.venice.meta.VeniceSerializer
 
deserialize(byte[], Schema, SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
deserialize(byte[], SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
deserialize(PubSubTopicPartition, byte[], byte[], PubSubMessageHeaders, Long, Long) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
Deserialize a message from the pubsub specific message format to PubSubMessage.
deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
Create an object from an array of bytes This method is used by the Kafka consumer.
deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
 
deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.DefaultSerializer
 
deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.KafkaKeySerializer
 
deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.StringSerializer
 
deserialize(String, byte[]) - Method in interface com.linkedin.venice.serialization.VeniceKafkaSerializer
Create an object from an array of bytes
deserialize(ByteBuffer) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
 
deserialize(ByteBuffer) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserialize(ByteBuffer) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserialize(ByteBuffer) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserialize(ByteBuffer, byte[]) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserialize(ByteBuffer, int) - Method in class com.linkedin.venice.controller.kafka.protocol.serializer.AdminOperationSerializer
 
deserialize(ByteBuffer, InputStream, BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserialize(ByteBuffer, ByteBuffer, BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserialize(ByteBuffer, BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserialize(CompletableFuture<Map<K, V>>, Iterable<E>, List<K>, BiConsumer<Map<K, V>, E>, Reporter, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.deserialization.BatchDeserializer
 
deserialize(CompletableFuture<Map<K, V>>, Iterable<E>, List<K>, BiConsumer<Map<K, V>, E>, Reporter, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.deserialization.BlackHoleDeserializer
 
deserialize(CompletableFuture<Map<K, V>>, Iterable<E>, List<K>, BiConsumer<Map<K, V>, E>, Reporter, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.deserialization.BlockingDeserializer
 
deserialize(BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserialize(BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserialize(BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserialize(T, byte[]) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserialize(T, InputStream, BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserialize(T, ByteBuffer, BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserialize(T, BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserialize(V, byte[]) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserialize(V, InputStream, BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserialize(V, ByteBuffer, BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserialize(V, BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserializeComputeRequest(BinaryDecoder, ComputeRequest) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
deserializedSchemaIds - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
deserializeIngestionActionRequest(IngestionAction, byte[]) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
deserializeIngestionActionResponse(IngestionAction, byte[]) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
deserializeObjects(byte[]) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserializeObjects(byte[]) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserializeObjects(byte[]) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserializeObjects(BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
deserializeObjects(BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
 
deserializeObjects(BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
 
deserializeRmdBytes(int, int, ByteBuffer) - Method in class com.linkedin.davinci.replication.merge.RmdSerDe
Given a value schema ID {@param valueSchemaID} and RMD bytes {@param rmdBytes}, find the RMD schema that corresponds to the given value schema ID and use that RMD schema to deserialize RMD bytes in a RMD record.
deserializeStoreVersionState(String, byte[]) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
deserializeValueSchemaIdPrependedRmdBytes(byte[], RmdWithValueSchemaId) - Method in class com.linkedin.davinci.replication.merge.RmdSerDe
This method takes in the RMD bytes with prepended value schema ID and a RmdWithValueSchemaId container object.
DEST_FABRIC - com.linkedin.venice.Arg
 
DEST_FABRIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
destClusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
destClusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
destinationIdentifier() - Method in interface com.linkedin.davinci.ingestion.consumption.ConsumedDataReceiver
N.B.: Used for defensive coding.
destinationIdentifier() - Method in class com.linkedin.davinci.kafka.consumer.StorePartitionDataReceiver
 
destroy() - Method in class com.linkedin.alpini.io.ExternalCommand
 
destroy() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
 
destroy(T) - Method in interface com.linkedin.alpini.base.pool.AsyncPool.LifeCycle
 
destroy(T) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleFilter
 
destroy(T) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
destroy(T) - Method in class com.linkedin.alpini.base.pool.impl.RateLimitedCreateLifeCycle
 
destroyIsolatedIngestionProcess(Process) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
destroyIsolatedIngestionProcessByPid(long) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
Kill isolated ingestion process by provided PID.
destroyLingeringIsolatedIngestionProcess(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
This method takes two steps to kill any lingering forked ingestion process previously created by the same user.
destroyQuietly(Process) - Static method in enum com.linkedin.alpini.base.misc.ProcessUtil
 
detail - Variable in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Error detail
detectAndHandleDuplicateKeys(byte[], byte[], Iterator<byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.DuplicateKeyPrinter
 
DETERMINISTIC_GUID_GENERATOR_IMPLEMENTATION - Static variable in class com.linkedin.venice.guid.GuidUtils
 
DeterministicGuidGenerator - Class in com.linkedin.venice.guid
 
DeterministicGuidGenerator(long, long) - Constructor for class com.linkedin.venice.guid.DeterministicGuidGenerator
 
DeterministicMapOrderDatumWriter - Interface in org.apache.avro.generic
This interface provides method to write map entries in a deterministic order.
DeterministicMapOrderGenericDatumWriter<T> - Class in org.apache.avro.generic
An Avro generic datum writer that sorts the map entries by keys before serializing the map.
DeterministicMapOrderGenericDatumWriter(GenericData) - Constructor for class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
 
DeterministicMapOrderGenericDatumWriter(Schema) - Constructor for class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
 
DeterministicMapOrderGenericDatumWriter(Schema, GenericData) - Constructor for class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
 
DeterministicMapOrderSpecificDatumWriter<T> - Class in org.apache.avro.specific
An Avro specific datum writer that sorts the map entries by keys before serializing the map.
DeterministicMapOrderSpecificDatumWriter() - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
 
DeterministicMapOrderSpecificDatumWriter(Class<T>) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
 
DeterministicMapOrderSpecificDatumWriter(Schema) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
 
DeterministicMapOrderSpecificDatumWriter(Schema, SpecificData) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
 
DeterministicMapOrderSpecificDatumWriter(SpecificData) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
 
DICT_LENGTH - Static variable in class com.linkedin.alpini.io.PigzOutputStream
 
DICTIONARY - com.linkedin.venice.meta.QueryAction
 
DICTIONARY_NOT_DOWNLOADED - com.linkedin.venice.router.stats.StaleVersionReason
 
DictionaryFetchRequest - Class in com.linkedin.venice.listener.request
DictionaryFetchRequest encapsulates a GET request to storage/storename/version on the storage node to fetch the compression dictionary for that version.
DictionaryRetrievalService - Class in com.linkedin.venice.router.api
DictionaryRetrievalService runs in a producer-consumer pattern.
DictionaryRetrievalService(OnlineInstanceFinder, VeniceRouterConfig, Optional<SSLFactory>, ReadOnlyStoreRepository, StorageNodeClient, CompressorFactory) - Constructor for class com.linkedin.venice.router.api.DictionaryRetrievalService
 
DictionaryUtils - Class in com.linkedin.venice.utils
 
DictionaryUtils() - Constructor for class com.linkedin.venice.utils.DictionaryUtils
 
diff(PubSubPosition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
diff(PubSubPosition) - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
 
difference(TimeValue) - Method in class com.linkedin.alpini.base.misc.TimeValue
Computes the difference between this timevalue and the supplied timevalue.
DirectionalSchemaCompatibilityType - Enum in com.linkedin.venice.schema.avro
 
directMemoryCapacity - Variable in class com.linkedin.venice.stats.VeniceJVMStats
An estimate of the total capacity of the buffers in this pool.
directMemoryPoolCount - Variable in class com.linkedin.venice.stats.VeniceJVMStats
An estimate of the number of buffers in the pool.
directMemoryUsage - Variable in class com.linkedin.venice.stats.VeniceJVMStats
Returns an estimate of the memory that the Java virtual machine is using for this buffer pool.
directory() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
directory(File) - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
directoryContainsFolder(String, String) - Static method in class com.linkedin.venice.utils.TestUtils
 
directoryExists(String) - Static method in class com.linkedin.venice.utils.Utils
 
DISABLE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.Command
 
DISABLE_DAVINCI_PUSH_STATUS_STORE - com.linkedin.venice.Arg
 
DISABLE_DAVINCI_PUSH_STATUS_STORE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
DISABLE_LOG - com.linkedin.venice.Arg
 
DISABLE_MAX_CAPACITY_PROTECTION - com.linkedin.venice.Command
 
DISABLE_META_STORE - com.linkedin.venice.Arg
 
DISABLE_META_STORE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
DISABLE_NATIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.Command
 
DISABLE_QUTOA_REBALANCE - com.linkedin.venice.Command
 
DISABLE_STORE - com.linkedin.venice.Command
 
DISABLE_STORE_READ - com.linkedin.venice.Command
 
DISABLE_STORE_READ - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DISABLE_STORE_VIEW - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
DISABLE_STORE_WRITE - com.linkedin.venice.Command
 
DISABLE_STORE_WRITE - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
DISABLE_THROTTLING - com.linkedin.venice.Command
 
disableAndDeleteStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
DISABLED - Static variable in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
 
disableDavinciPushStatusStore - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
An UpdateStore command option to disable the companion davinci push status store
disableDavinciPushStatusStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
DisabledPartitionEnablerService - Class in com.linkedin.venice.controller
 
DisabledPartitionEnablerService(VeniceHelixAdmin, VeniceControllerMultiClusterConfig) - Constructor for class com.linkedin.venice.controller.DisabledPartitionEnablerService
 
DisabledPartitionEnablerService(VeniceHelixAdmin, VeniceControllerMultiClusterConfig, Time) - Constructor for class com.linkedin.venice.controller.DisabledPartitionEnablerService
 
DisabledPartitionStats - Class in com.linkedin.venice.controller.stats
 
DisabledPartitionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.DisabledPartitionStats
 
disableLog() - Static method in class com.linkedin.venice.LogConfigurator
 
disableMetaStore - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
An UpdateStore command option to disable the companion meta system store
disableMetaStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
disableMetricsEmission() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
disableParentTopicTruncationUponCompletion() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
disableReplica(String, int) - Method in interface com.linkedin.venice.pushmonitor.DisableReplicaCallback
 
DisableReplicaCallback - Interface in com.linkedin.venice.pushmonitor
The callback method to disable leader replicas whenever they are in ERROR state so that helix can elect a new leader.
disableRetryOnTimeout() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
disableRetryOnTimeout(BooleanSupplier) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
DisableStoreRead - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
DisableStoreRead() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
Default constructor.
DisableStoreRead(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
All-args constructor.
disconnect() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
disconnect(ChannelHandlerContext, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
DISCONNECTED - com.linkedin.venice.meta.InstanceStatus
 
discoverAndConstructControllerClient(String, String, int, D2Client) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
 
discoverAndConstructControllerClient(String, String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
 
discoverAndConstructControllerClient(String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
discoverAndConstructControllerClient(String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.ControllerClientFactory
 
discoverCluster(D2Client, String, String) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
 
discoverCluster(D2Client, String, String, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
 
discoverCluster(Admin) - Static method in class com.linkedin.venice.controller.server.ClusterDiscovery
No ACL check; any user is allowed to discover cluster
discoverCluster(String) - Method in interface com.linkedin.venice.controller.Admin
Find the cluster which the given store belongs to.
discoverCluster(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
discoverCluster(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
discoverCluster(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
discoverCluster(String) - Method in class com.linkedin.venice.controllerapi.D2ControllerClient
 
discoverCluster(String, String, String, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
Deprecated.
discoverCluster(String, String, String, int, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
 
discoverCluster(String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
 
discoverLeaderController() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
discoverLeaderController() - Method in class com.linkedin.venice.controllerapi.D2ControllerClient
 
DISCOVERY_ERROR - com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
 
DISK - com.linkedin.davinci.client.StorageClass
The mode has the following implications: 1.
DiskHealthCheckService - Class in com.linkedin.davinci.storage
DiskHealthCheckService will wake up every 10 seconds by default and run a health check in the disk by writing 64KB random data, read them back and verify the content; if there is any error within the process, an in-memory state variable "diskHealthy" will be updated to false; otherwise, "diskHealthy" will be kept as true.
DiskHealthCheckService(boolean, long, long, String, long) - Constructor for class com.linkedin.davinci.storage.DiskHealthCheckService
 
DiskHealthStats - Class in com.linkedin.venice.stats
DiskHealthStats measures the disk health conditions based on the periodic tests ran by the DiskHealthCheckService.
DiskHealthStats(MetricsRepository, DiskHealthCheckService, String) - Constructor for class com.linkedin.venice.stats.DiskHealthStats
 
DiskLimitExhaustedException - Exception in com.linkedin.venice.exceptions
 
DiskLimitExhaustedException(String) - Constructor for exception com.linkedin.venice.exceptions.DiskLimitExhaustedException
 
DiskLimitExhaustedException(String, int, String) - Constructor for exception com.linkedin.venice.exceptions.DiskLimitExhaustedException
 
diskUsage - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
DiskUsage - Class in com.linkedin.venice.utils
We define a threshold where we consider the disk to be full.
DiskUsage(String, double) - Constructor for class com.linkedin.venice.utils.DiskUsage
 
dispatch(Scatter<Instance, VenicePath, RouterKey>, ScatterGatherRequest<Instance, RouterKey>, VenicePath, BasicHttpRequest, AsyncPromise<Instance>, AsyncPromise<List<FullHttpResponse>>, AsyncPromise<HttpResponseStatus>, AsyncFuture<Void>, Executor) - Method in class com.linkedin.venice.router.api.VeniceDispatcher
 
dispatch(Scatter<H, P, K>, ScatterGatherRequest<H, K>, P, BASIC_HTTP_REQUEST, AsyncPromise<H>, AsyncPromise<List<HTTP_RESPONSE>>, AsyncPromise<HTTP_RESPONSE_STATUS>, AsyncFuture<Void>, Executor) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
dispatch(Scatter<H, P, K>, ScatterGatherRequest<H, K>, P, BHS, AsyncPromise<H>, AsyncPromise<List<HR>>, AsyncPromise<HRS>, AsyncFuture<Void>, Executor) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
dispatch(Scatter<H, P, K>, ScatterGatherRequest<H, K>, P, HTTP_REQUEST, AsyncPromise<H>, AsyncPromise<List<HTTP_RESPONSE>>, AsyncPromise<HTTP_RESPONSE_STATUS>, AsyncFuture<Void>, Executor) - Method in interface com.linkedin.alpini.router.api.PartitionDispatchHandler
Performs the work.
dispatcherNettyVersion() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
dispatchHandler(PartitionDispatchHandler<H, P, K, DISPATCH_REQUEST, DISPATCH_RESPONSE, DISPATCH_RESPONSE_STATUS>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
DispatchingAvroGenericStoreClient<K,​V> - Class in com.linkedin.venice.fastclient
This class is in charge of routing and serialization/de-serialization.
DispatchingAvroGenericStoreClient(StoreMetadata, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
DispatchingAvroGenericStoreClient(StoreMetadata, ClientConfig, TransportClient) - Constructor for class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
DispatchingAvroSpecificStoreClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient
 
DispatchingAvroSpecificStoreClient(StoreMetadata, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DispatchingAvroSpecificStoreClient
 
DispatchingVsonStoreClient<K,​V> - Class in com.linkedin.venice.fastclient
Deprecated.
DispatchingVsonStoreClient(StoreMetadata, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DispatchingVsonStoreClient
Deprecated.
 
dispatchMinimumMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
display() - Method in class com.linkedin.venice.ControlMessageDumper
Display control messages from each producer
displayTaskResult(DataRecoveryTask) - Method in class com.linkedin.venice.datarecovery.DataRecoveryEstimator
 
displayTaskResult(DataRecoveryTask) - Method in class com.linkedin.venice.datarecovery.DataRecoveryExecutor
 
displayTaskResult(DataRecoveryTask) - Method in class com.linkedin.venice.datarecovery.DataRecoveryMonitor
 
dispose(O) - Method in class com.linkedin.venice.utils.pools.LandFillObjectPool
 
dispose(O) - Method in interface com.linkedin.venice.utils.pools.ObjectPool
Return an object to the pool, indicating that it will no longer be used and can be recycled.
dispose(T) - Method in interface com.linkedin.alpini.base.pool.AsyncPool
 
dispose(T) - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
dispose0(T) - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
DIV_PRODUCER_STATE_MAX_AGE_MS - Static variable in class com.linkedin.venice.ConfigKeys
The maximum age (in milliseconds) of producer state retained by Data Ingestion Validation.
divErrorMetricCallback - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
DIVStats - Class in com.linkedin.davinci.stats
This class contains stats for DIV.
DIVStats() - Constructor for class com.linkedin.davinci.stats.DIVStats
 
DIVStatsReporter - Class in com.linkedin.davinci.stats
This class is the reporting class for stats class DIVStats.
DIVStatsReporter(MetricsRepository, String) - Constructor for class com.linkedin.davinci.stats.DIVStatsReporter
 
DIVStatsReporter.DIVStatsCounter - Class in com.linkedin.davinci.stats
 
DnsLookupStats - Class in com.linkedin.venice.stats
 
DnsLookupStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.DnsLookupStats
 
doesResourcesExistInIdealState(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
doesResourcesExistInIdealState(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Whether the resources names exist in ideal state or not.
doesResultReuseInput() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
 
doesSslRequireClientCerts() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
doesSslRequireClientCerts() - Method in class com.linkedin.venice.security.SSLConfig
 
done() - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
Use the methods provided by the CompletionStage interface to perform actions after the completion of the task.
DONE - com.linkedin.alpini.base.concurrency.AsyncFuture.Status
 
doSimpleTask(EventExecutor) - Method in class com.linkedin.alpini.netty4.handlers.Http2PingResponseHandler
 
doStart() - Method in class com.linkedin.venice.d2.D2ServerManager
 
DOT - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
DOT_PRODUCT - com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
 
DOT_PRODUCT_RESULT_SCHEMA - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
DOT_PRODUCT_SPEC - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
dotProduct(String, List<Float>, String) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
dotProduct(String, List<Float>, String) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Setup dot-product operation.
dotProduct(List<Float>, List<Float>) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
DotProduct - Class in com.linkedin.venice.compute.protocol.request
 
DotProduct() - Constructor for class com.linkedin.venice.compute.protocol.request.DotProduct
Default constructor.
DotProduct(CharSequence, List<Float>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.DotProduct
All-args constructor.
DotProductOperator - Class in com.linkedin.venice.compute
 
DotProductOperator() - Constructor for class com.linkedin.venice.compute.DotProductOperator
 
dotProductParam - Variable in class com.linkedin.venice.compute.protocol.request.DotProduct
The passed feature vector, which will be used to execute dot-product calculation against the field in the original value record
DoubleQuantileEstimation - Class in com.linkedin.alpini.base.statistics
 
DoubleQuantileEstimation(double, int) - Constructor for class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation
 
DoubleQuantileEstimation.Sample - Class in com.linkedin.alpini.base.statistics
 
DoubleWelford() - Constructor for class com.linkedin.alpini.base.statistics.Welfords.DoubleWelford
 
DoubleWelford(Welfords.DoubleWelford) - Constructor for class com.linkedin.alpini.base.statistics.Welfords.DoubleWelford
 
DoublyLinkedList<E extends DoublyLinkedList.Entry<E>> - Class in com.linkedin.alpini.base.misc
Linked list implementation of the List interface.
DoublyLinkedList() - Constructor for class com.linkedin.alpini.base.misc.DoublyLinkedList
Constructs an empty list.
DoublyLinkedList(Collection<? extends E>) - Constructor for class com.linkedin.alpini.base.misc.DoublyLinkedList
Constructs a list containing the elements of the specified collection, in the order they are returned by the collection's iterator.
DoublyLinkedList.Entry<E extends DoublyLinkedList.Entry<E>> - Class in com.linkedin.alpini.base.misc
In order to maintain a doubly-linked list, each element needs to establish links to its adjacent elements.
doUpdateSupersetSchemaID - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Whether this superset schema ID should be updated to be the value schema ID for this store.
drainBufferedRecordsFromTopicPartition(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
This method will wait for all the messages to be processed (persisted to disk) that are already queued up to drainer till now.
drainBufferedRecordsFromTopicPartition(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
drainBufferedRecordsFromTopicPartition(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
This function is used to drain all the records for the specified topic + partition.
drainTo(Collection<? super E>) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
drainTo(Collection<? super E>, int) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
drainTo(Collection<? super T>) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
drainTo(Collection<? super T>, int) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
drop() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Drop the whole store
drop() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Drop when it is not required anymore.
drop() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
drop() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
drop() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
drop() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
drop() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
drop() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
dropMetadataPartition() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
dropPartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Removes and returns a partition from the current store
DROPPED - com.linkedin.venice.helix.HelixState
 
DROPPED - com.linkedin.venice.pushmonitor.ExecutionStatus
Deprecated.
DROPPED_STATE - Static variable in enum com.linkedin.venice.helix.HelixState
 
dropResource(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Drop a resource from a cluster.
dropResource(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
dropStorageInstance(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Drop a storage node instance from the given cluster.
dropStorageInstance(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
This method stops to subscribe the specified topic partition and delete partition data from storage and it will always drop empty storage engine.
dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int, boolean) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int, boolean) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
This method stops to subscribe the specified topic partition and delete partition data from storage.
dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int, boolean) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
dropStorePartition(VeniceStoreVersionConfig, int) - Method in class com.linkedin.davinci.storage.StorageService
Drops the partition of the specified store version in the storage service.
dropStorePartition(VeniceStoreVersionConfig, int, boolean) - Method in class com.linkedin.davinci.storage.StorageService
Drops the partition of the specified store version in the storage service.
DUAL_POOL_STRATEGY - com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory.LeaderFollowerThreadPoolStrategy
 
DualReadAvroGenericStoreClient<K,​V> - Class in com.linkedin.venice.fastclient
The following class has capability to send dual read requests via Fast-client and Thin-client.
DualReadAvroGenericStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DualReadAvroGenericStoreClient
 
DualReadAvroGenericStoreClient(InternalAvroStoreClient<K, V>, ClientConfig, AvroGenericStoreClient<K, V>) - Constructor for class com.linkedin.venice.fastclient.DualReadAvroGenericStoreClient
 
DualReadAvroSpecificStoreClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient
 
DualReadAvroSpecificStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DualReadAvroSpecificStoreClient
 
DUMP_ADMIN_MESSAGES - com.linkedin.venice.Command
 
DUMP_CONTROL_MESSAGES - com.linkedin.venice.Command
 
DUMP_INGESTION_STATE - com.linkedin.venice.Command
 
DUMP_INGESTION_STATE - com.linkedin.venice.meta.ServerAdminAction
 
DUMP_KAFKA_TOPIC - com.linkedin.venice.Command
 
DUMP_SERVER_CONFIGS - com.linkedin.venice.meta.ServerAdminAction
 
DUMP_TOPIC_PARTITION_INGESTION_CONTEXT - com.linkedin.venice.Command
 
dumpAdminMessages(PubSubConsumerAdapter, String, long, int) - Static method in class com.linkedin.venice.DumpAdminMessages
 
DumpAdminMessages - Class in com.linkedin.venice
The design consideration to consume in admin tool directly instead of letting controller to consume the required admin message and return them back to admin tool: 1.
DumpAdminMessages() - Constructor for class com.linkedin.venice.DumpAdminMessages
 
DumpAdminMessages.AdminOperationInfo - Class in com.linkedin.venice
 
dumpPartitionConsumptionStates(AdminResponse, ComplementSet<Integer>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Invoked by admin request to dump the requested partition consumption states
dumpStoreVersionState(AdminResponse) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Invoked by admin request to dump store version state metadata.
DUP_KEY_WITH_DIFF_VALUE - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
DUP_KEY_WITH_DISTINCT_VALUE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
DUP_KEY_WITH_IDENTICAL_VALUE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Construct a full copy of the request.
duplicate() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
duplicate() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
duplicate() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
DUPLICATE_MESSAGE - com.linkedin.davinci.kafka.consumer.StoreIngestionTask.DelegateConsumerRecordResult
The consumer record is a duplicated message.
DUPLICATE_VALUE_SCHEMA_CODE - Static variable in class com.linkedin.venice.schema.SchemaData
 
duplicate0() - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
duplicate0() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
DuplicateDataException - Exception in com.linkedin.venice.exceptions.validation
This is a benign DataValidationException.
DuplicateDataException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.DuplicateDataException
 
DuplicateDataException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.validation.DuplicateDataException
 
duplicateKeyWithDistinctValueCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
duplicateKeyWithIdenticalValueCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
DuplicateTopicException - Exception in com.linkedin.venice.ingestion.control
The source and destination topic for topic switching are the same topic
DuplicateTopicException(String) - Constructor for exception com.linkedin.venice.ingestion.control.DuplicateTopicException
 
DuplicatingPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
A PollStrategy implementation which can introduce duplicates.
DuplicatingPollStrategy(AbstractPollStrategy, Set<PubSubTopicPartitionOffset>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.DuplicatingPollStrategy
 
DurableWrite - Class in com.linkedin.venice.producer
This class is used as the return type of the CompletableFuture that is returned by the Venice producer.
DurableWrite() - Constructor for class com.linkedin.venice.producer.DurableWrite
 
DVC_INGESTION_ERROR_DISK_FULL - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
DVC_INGESTION_ERROR_DISK_FULL - com.linkedin.venice.pushmonitor.ExecutionStatus
DaVinci client fails ingestion due to disk reaching the threshold in the host
DVC_INGESTION_ERROR_MEMORY_LIMIT_REACHED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
DVC_INGESTION_ERROR_MEMORY_LIMIT_REACHED - com.linkedin.venice.pushmonitor.ExecutionStatus
DaVinci client fails ingestion due to reaching the configured memory limit in the host
DVC_INGESTION_ERROR_OTHER - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
DVC_INGESTION_ERROR_OTHER - com.linkedin.venice.pushmonitor.ExecutionStatus
Other uncategorized DaVinci Client errors
DVC_INGESTION_ERROR_TOO_MANY_DEAD_INSTANCES - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
DVC_INGESTION_ERROR_TOO_MANY_DEAD_INSTANCES - com.linkedin.venice.pushmonitor.ExecutionStatus
There are too many dead DaVinci instances leading to failed push job
DynamicAccessController - Interface in com.linkedin.venice.acl
A DynamicAccessController is an AccessController with a mutable resource list.

E

EARLY_THROTTLE_ENABLED - Static variable in class com.linkedin.venice.router.AdminOperationsHandler
 
element() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Returns the first element in this list.
element() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
ElementTimestampAndIdx - Class in com.linkedin.venice.schema.rmd.v1
A POJO containing an index and a timestamp for a collection element.
ElideDuplicateHeadersHandler - Class in com.linkedin.alpini.netty4.handlers
A simple cache to reduce the number of duplicate CharSequences held by the HttpHeaders instances.
EMERGENCY_SOURCE_REGION - Static variable in class com.linkedin.venice.ConfigKeys
The highest priority source fabric selection config, specified in parent controller.
emitMetrics - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
empty() - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
empty() - Static method in class com.linkedin.venice.utils.VeniceProperties
 
EMPTY - Static variable in class com.linkedin.venice.utils.ByteArray
 
EMPTY_BYTE_ARRAY - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
EMPTY_BYTE_BUF - Static variable in class com.linkedin.venice.router.streaming.VeniceChunkedResponse
 
EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.venice.streaming.StreamingUtils
 
EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.venice.writer.WriterChunkingHelper
 
EMPTY_HEADERS - Static variable in interface com.linkedin.alpini.base.misc.Headers
 
EMPTY_KEY_LENGTH - Static variable in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
 
EMPTY_PUSH - com.linkedin.venice.Command
 
EMPTY_PUSH - com.linkedin.venice.controllerapi.ControllerRoute
 
EMPTY_RECORD_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
EMPTY_RECORD_HEADERS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaUtils
 
EMPTY_STRING - Static variable in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
emptyPollSleepMs - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
EmptyPubSubMessageHeaders - Class in com.linkedin.venice.pubsub.api
 
emptyPush(Admin) - Method in class com.linkedin.venice.controller.server.CreateVersion
 
emptyPush(String, String, long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
emptyRecordCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
emptySet() - Static method in class com.linkedin.venice.utils.ComplementSet
 
ENABLE_ACTIVE_ACTIVE_REPLICATION_AS_DEFAULT_FOR_BATCH_ONLY_STORE - Static variable in class com.linkedin.venice.ConfigKeys
Cluster-level config to enable active-active replication for new batch-only stores.
ENABLE_ACTIVE_ACTIVE_REPLICATION_AS_DEFAULT_FOR_HYBRID_STORE - Static variable in class com.linkedin.venice.ConfigKeys
Cluster-level config to enable active-active replication for new hybrid stores.
ENABLE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.Command
 
ENABLE_BLOB_TRANSFER - Static variable in class com.linkedin.venice.ConfigKeys
Store-level config to enable blob transfers (feature flag)
ENABLE_CHUNKING - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
ENABLE_DISABLED_REPLICA - com.linkedin.venice.Arg
 
ENABLE_DISABLED_REPLICAS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
ENABLE_GRPC_READ_SERVER - Static variable in class com.linkedin.venice.ConfigKeys
 
ENABLE_HYBRID_PUSH_SSL_ALLOWLIST - Static variable in class com.linkedin.venice.ConfigKeys
The switcher to enable/disable the allowlist of ssl hybrid pushes including both batch and near-line pushes for that store.
ENABLE_HYBRID_PUSH_SSL_WHITELIST - Static variable in class com.linkedin.venice.ConfigKeys
Deprecated.
ENABLE_INCREMENTAL_PUSH_FOR_HYBRID_ACTIVE_ACTIVE_USER_STORES - Static variable in class com.linkedin.venice.ConfigKeys
We will use this config to determine whether we should enable incremental push for hybrid active-active user stores.
ENABLE_MAX_CAPACITY_PROTECTION - com.linkedin.venice.Command
 
ENABLE_MAX_CAPACITY_PROTECTION - com.linkedin.venice.controllerapi.ControllerRoute
 
ENABLE_NATIVE_REPLICATION_AS_DEFAULT_FOR_BATCH_ONLY - Static variable in class com.linkedin.venice.ConfigKeys
Cluster-level config to enable native replication for new batch-only stores.
ENABLE_NATIVE_REPLICATION_AS_DEFAULT_FOR_HYBRID - Static variable in class com.linkedin.venice.ConfigKeys
Cluster-level config to enable native replication for new hybrid stores.
ENABLE_NATIVE_REPLICATION_FOR_BATCH_ONLY - Static variable in class com.linkedin.venice.ConfigKeys
Cluster-level config to enable native replication for all batch-only stores.
ENABLE_NATIVE_REPLICATION_FOR_CLUSTER - com.linkedin.venice.Command
 
ENABLE_NATIVE_REPLICATION_FOR_HYBRID - Static variable in class com.linkedin.venice.ConfigKeys
Cluster-level config to enable native replication for all hybrid stores.
ENABLE_OFFLINE_PUSH_SSL_ALLOWLIST - Static variable in class com.linkedin.venice.ConfigKeys
The switcher to enable/disable the allowlist of ssl offline pushes.
ENABLE_OFFLINE_PUSH_SSL_WHITELIST - Static variable in class com.linkedin.venice.ConfigKeys
Deprecated.
ENABLE_PARTIAL_UPDATE_FOR_HYBRID_ACTIVE_ACTIVE_USER_STORES - Static variable in class com.linkedin.venice.ConfigKeys
We will use this config to determine whether we should enable partial update for hybrid active-active user stores.
ENABLE_PARTIAL_UPDATE_FOR_HYBRID_NON_ACTIVE_ACTIVE_USER_STORES - Static variable in class com.linkedin.venice.ConfigKeys
We will use this config to determine whether we should enable partial update for hybrid non-active-active user stores.
ENABLE_PARTITION_COUNT_ROUND_UP - Static variable in class com.linkedin.venice.ConfigKeys
Whether to round up the version-level partition count calculated by storage quota.
ENABLE_QUOTA_REBALANCED - com.linkedin.venice.controllerapi.ControllerRoute
 
ENABLE_QUTOA_REBALANCE - com.linkedin.venice.Command
 
ENABLE_READS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
ENABLE_RMD_CHUNKING - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
ENABLE_SERVER_ALLOW_LIST - Static variable in class com.linkedin.venice.ConfigKeys
 
ENABLE_SSL - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
ENABLE_STORE - com.linkedin.venice.Command
 
ENABLE_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
ENABLE_STORE_READ - com.linkedin.venice.Command
 
ENABLE_STORE_READ - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
ENABLE_STORE_WRITE - com.linkedin.venice.Command
 
ENABLE_STORE_WRITE - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
ENABLE_THROTTLING - com.linkedin.venice.Command
 
ENABLE_THROTTLING - com.linkedin.venice.controllerapi.ControllerRoute
 
ENABLE_WRITE_COMPUTE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
ENABLE_WRITES - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
enableActiveActiveReplicationForCluster(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
enabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
enabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
enabledIncrementalPushForHybridActiveActiveUserStores() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
enableDisabledPartition(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
enableInboundHttp2(boolean) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
enableInboundHttp2(boolean) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
enableInboundHttp2(boolean) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
enableMaxCapacityProtection(boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
enableMaxCapacityProtection(boolean) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
enableMaxCapacityProtection(boolean) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Enable or disable max read capacity protection feature on router.
enableMaxCapacityProtection(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
Enable max capacity protection by updating the cluster level for all routers.
enableMetricsEmission() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
enableNativeReplicationForCluster(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
enablePartition(boolean, String, String, String, List<String>) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Disable or enable a list of partitions on an instance.
enablePartition(boolean, String, String, String, List<String>) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
enablePeriodicPing() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
enablePushJobStatusUpload - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
enableQuotaRebalanced(boolean, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
enableQuotaRebalanced(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
Enable quota rebalanced by updating the cluster level for all routers.
enableReads - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
enableReads - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
enableReads - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
If a store is disabled from being read, none of versions under this store could serve read requests.
enableResolveBeforeSSL(EventExecutorGroup, int, long) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Configure for performing DNS resolution of the client address on an alternate thread pool to avoid and limit DNS execution during SSL handshake from blocking the IO Workers.
enableResolveBeforeSSL(EventExecutorGroup, int, long, int) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Configure for performing DNS resolution of the client address on an alternate thread pool to avoid and limit DNS execution during SSL handshake from blocking the IO Workers.
enableRetryRequestAlwaysUseADifferentHost(boolean) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
enableRetryRequestAlwaysUseADifferentHost(BooleanSupplier) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
enableSSL - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
enableSslTaskExecutor(Executor) - Method in class com.linkedin.alpini.netty4.ssl.SslClientInitializer
Configure for enabling the SslHandler to offload handshake compute tasks to an alternate executor.
enableSslTaskExecutor(Executor) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Configure for enabling the SslHandler to offload handshake compute tasks to an alternate executor.
enableStackTraceResponseForException(boolean) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
enableStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
enable/disable store read/write ability
EnableStoreRead - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
EnableStoreRead() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
Default constructor.
EnableStoreRead(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
All-args constructor.
enableStoreReads(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
enableStoreReadWrites(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
enableStoreWrites(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
enableThrottling(boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
enableThrottling(boolean) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
enableThrottling(boolean) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Enable or disable read throttling feature on router.
enableThrottling(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
Enable throttling by updating the cluster level for all routers.
enableWriteCompute - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
enableWrites - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
enableWrites - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
enableWrites - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
If a store is disabled from writing, new version can not be created for it.
encode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
encode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
Encode from an HttpObject to an Http2StreamFrame.
encode(ChannelHandlerContext, I, List<Object>) - Method in class io.netty.handler.codec.EspressoMessageToMessageEncoder
Encode from one message to an other.
encode(ChannelHandlerContext, Object, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.HttpByteBufContentChunker
 
encode(ChannelHandlerContext, Object, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentEncoder
 
encode(ChannelHandlerContext, Object, List<Object>) - Method in class io.netty.handler.codec.http.EspressoHttpObjectEncoder
 
encode(CharSequence, Charset) - Static method in enum com.linkedin.alpini.base.misc.URLCodec
Translates a string into application/x-www-form-urlencoded format using a specific encoding scheme.
encode(CharSequence, Charset) - Static method in enum com.linkedin.alpini.netty4.misc.AsciiStringURLCodec
Translates a string into application/x-www-form-urlencoded format using a specific encoding scheme.
encode(String, Charset) - Static method in enum com.linkedin.alpini.base.misc.URLCodec
Translates a string into application/x-www-form-urlencoded format using a specific encoding scheme.
encodeAscii(String, ByteBuf) - Static method in class io.netty.handler.codec.http.EspressoHttpObjectEncoder
Deprecated.
encodeHeaders(HttpHeaders, ByteBuf) - Method in class io.netty.handler.codec.http.EspressoHttpObjectEncoder
Encode the HttpHeaders into a ByteBuf.
encodeInitialLine(ByteBuf, HttpMultiPart) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentEncoder
 
encodeInitialLine(ByteBuf, H) - Method in class io.netty.handler.codec.http.EspressoHttpObjectEncoder
 
encodeInitialLine(ByteBuf, HttpResponse) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Encoder
 
encodeQueryParams(QueryParams) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
 
Encoder() - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Encoder
 
encodeTime(long) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
EncodingUtils - Class in com.linkedin.venice.utils
 
EncodingUtils() - Constructor for class com.linkedin.venice.utils.EncodingUtils
 
end(boolean) - Method in class com.linkedin.venice.kafka.validation.Segment
 
END_DATE - com.linkedin.venice.Arg
 
END_FABRIC_BUILDOUT - com.linkedin.venice.Command
 
END_MIGRATION - com.linkedin.venice.Command
 
END_OF_FINAL_SEGMENT - com.linkedin.venice.kafka.validation.SegmentStatus
Received ControlMessageType.END_OF_SEGMENT with finalSegment = true.
END_OF_INCREMENTAL_PUSH - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
END_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
END_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.pushmonitor.ExecutionStatus
An incremental push job/task is completed
END_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
END_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.status.PushJobDetailsStatus
 
END_OF_INTERMEDIATE_SEGMENT - com.linkedin.venice.kafka.validation.SegmentStatus
Received ControlMessageType.END_OF_SEGMENT with finalSegment = false.
END_OF_PUSH - com.linkedin.venice.authorization.Method
 
END_OF_PUSH - com.linkedin.venice.controllerapi.ControllerRoute
 
END_OF_PUSH - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
END_OF_PUSH_RECEIVED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
END_OF_PUSH_RECEIVED - com.linkedin.venice.pushmonitor.ExecutionStatus
Tasks belonging to a Hybrid Store emits this instead of ExecutionStatus.COMPLETED when it consumes a EOP message
END_OF_PUSH_RECEIVED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
END_OF_PUSH_RECEIVED - com.linkedin.venice.status.PushJobDetailsStatus
 
END_OF_SEGMENT - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
endBatchWrite() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
endBatchWrite() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
endBatchWrite() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
endBatchWrite(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
endOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
endOffset(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the end offset for the specified PubSub topic-partition.
endOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
endOffsets(String, int) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
 
endOffsets(Collection<PubSubTopicPartition>, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
endOffsets(Collection<PubSubTopicPartition>, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the end offsets for a collection of PubSub topic-partitions.
endOffsets(Collection<PubSubTopicPartition>, Duration) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
EndOfIncrementalPush - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent per partition by each offline incremental push job, once per partition, at the end of a incremental push
EndOfIncrementalPush() - Constructor for class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
Default constructor.
EndOfIncrementalPush(CharSequence) - Constructor for class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
All-args constructor.
endOfIncrementalPushReceived(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Consumption is completed for an incremental push
endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
endOfIncrementalPushReceived(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
endOfPush - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
Whether the EndOfPush control message was consumed in this partition.
EndOfPush - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent once per partition, at the end of a bulk load, after all of the data producers come online.
EndOfPush() - Constructor for class com.linkedin.venice.kafka.protocol.EndOfPush
 
endOfPushReceived(long) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
endOfPushReceived(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
The ControlMessageType.END_OF_PUSH control message was consumed.
endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
endOfPushReceived(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
endOfPushTimestamp - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
The messageTimestamp from the producerMetadata of EndOfPush control message.
EndOfSegment - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent at least once per partition per producer.
EndOfSegment() - Constructor for class com.linkedin.venice.kafka.protocol.EndOfSegment
Default constructor.
EndOfSegment(ByteBuffer, List<Long>, Boolean) - Constructor for class com.linkedin.venice.kafka.protocol.EndOfSegment
All-args constructor.
endSegment(int, boolean) - Method in class com.linkedin.venice.writer.VeniceWriter
 
endStreamReprocessingSystemProducer(SystemProducer, boolean) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
RouterBasedPushMonitor will update the status of a SystemProducer with push type STREAM_REPROCESSING: END_OF_PUSH_RECEIVED: isActive -> false; isStreamReprocessingJobSucceeded -> true COMPLETED: isActive -> false; isStreamReprocessingJobSucceeded -> true ERROR: isActive -> false; isStreamReprocessingJobSucceeded -> false For all the other push job status, SystemProducer status will not be updated.
endsWith(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string to determine if the specified string is a suffix.
ENFORCE_SECURE_ROUTER - Static variable in class com.linkedin.venice.ConfigKeys
Whether to block storage requests on the non-ssl port.
enforceMemoryLimit(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
Whether memory limiter applies or not.
enforceMemoryLimitInStore(String) - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
enforcePartitionQuota(int, long) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
EngineTaskConfigProvider - Interface in com.linkedin.venice.hadoop.engine
An interface to get information about a running job and task on any batch computing engine.
enlargeByteBufferForIntHeader(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
This function is to simulate the deserialization logic in com.linkedin.venice.serialization.avro.OptimizedKafkaValueSerializer to leave some room at the beginning of byte buffer of 'byteBuffer'
ensureTopicIsDeletedAndBlock(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Delete a topic and block until it is deleted or operation times out.
ensureTopicIsDeletedAndBlockWithRetry(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Delete a topic with retry and block until it is deleted or operation times out.
ensureWritable(int) - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
ensureWritable(int, boolean) - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
entries() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
entry() - Method in class com.linkedin.alpini.log.FastLogger
 
entry(Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
entry(K, V) - Static method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
 
Entry() - Constructor for class com.linkedin.alpini.base.misc.DoublyLinkedList.Entry
 
entrySet() - Method in class com.linkedin.alpini.base.misc.ArrayMap
entrySet() - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns a Set view of the mappings contained in this map.
EnumUtils - Class in com.linkedin.venice.utils
 
EnumUtils() - Constructor for class com.linkedin.venice.utils.EnumUtils
 
environment() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
ENVIRONMENT_CONFIG_KEY_FOR_REGION_NAME - Static variable in class com.linkedin.venice.VeniceConstants
 
EOF - Static variable in enum com.linkedin.alpini.io.IOUtils
 
EPOLL - com.linkedin.alpini.netty4.misc.NettyUtils.Mode
 
equals(Object) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
equals(Object) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
equals(Object) - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
equals(Object) - Method in class com.linkedin.alpini.base.misc.Pair
Test for equality between this and obj.
equals(Object) - Method in class com.linkedin.alpini.base.misc.TimeValue
 
equals(Object) - Method in class com.linkedin.alpini.consts.Level
 
equals(Object) - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
 
equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
equals(Object) - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
 
equals(Object) - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
 
equals(Object) - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
equals(Object) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
equals(Object) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
equals(Object) - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
equals(Object) - Method in class com.linkedin.davinci.utils.ByteArrayKey
 
equals(Object) - Method in class com.linkedin.venice.authorization.AceEntry
 
equals(Object) - Method in class com.linkedin.venice.authorization.AclBinding
 
equals(Object) - Method in class com.linkedin.venice.authorization.Principal
 
equals(Object) - Method in class com.linkedin.venice.authorization.Resource
 
equals(Object) - Method in class com.linkedin.venice.client.store.ClientConfig
 
equals(Object) - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
 
equals(Object) - Method in class com.linkedin.venice.compression.GzipCompressor
 
equals(Object) - Method in class com.linkedin.venice.compression.NoopCompressor
 
equals(Object) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
equals(Object) - Method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
 
equals(Object) - Method in class com.linkedin.venice.kafka.validation.Segment
 
equals(Object) - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
equals(Object) - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
equals(Object) - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
equals(Object) - Method in class com.linkedin.venice.meta.Instance
 
equals(Object) - Method in class com.linkedin.venice.meta.Partition
 
equals(Object) - Method in class com.linkedin.venice.meta.PartitionAssignment
 
equals(Object) - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
equals(Object) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
equals(Object) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
equals(Object) - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
equals(Object) - Method in class com.linkedin.venice.meta.SystemStore
 
equals(Object) - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
equals(Object) - Method in class com.linkedin.venice.meta.VersionImpl
 
equals(Object) - Method in class com.linkedin.venice.meta.ZKStore
 
equals(Object) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
equals(Object) - Method in class com.linkedin.venice.persona.Persona
 
equals(Object) - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
equals(Object) - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
equals(Object) - Method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
equals(Object) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeader
 
equals(Object) - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
 
equals(Object) - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
 
equals(Object) - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
 
equals(Object) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
equals(Object) - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
 
equals(Object) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
equals(Object) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
equals(Object) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
equals(Object) - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
 
equals(Object) - Method in class com.linkedin.venice.router.api.RouterKey
 
equals(Object) - Method in class com.linkedin.venice.router.api.VeniceFullHttpResponse
 
equals(Object) - Method in class com.linkedin.venice.routerapi.ReplicaState
 
equals(Object) - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
equals(Object) - Method in class com.linkedin.venice.schema.GeneratedSchemaEntry
 
equals(Object) - Method in class com.linkedin.venice.schema.GeneratedSchemaID
 
equals(Object) - Method in class com.linkedin.venice.schema.rmd.RmdSchemaEntry
 
equals(Object) - Method in class com.linkedin.venice.schema.rmd.RmdVersionId
 
equals(Object) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
equals(Object) - Method in class com.linkedin.venice.schema.SchemaEntry
 
equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
Deprecated.
 
equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsHashMap
Deprecated.
 
equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
equals(Object) - Method in class com.linkedin.venice.serializer.SerializerDeserializerFactory.SchemaPairAndClassContainer
 
equals(Object) - Method in class com.linkedin.venice.status.StoreStatusMessage
 
equals(Object) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
 
equals(Object) - Method in class com.linkedin.venice.utils.ByteArray
 
equals(Object) - Method in class com.linkedin.venice.utils.HashCodeComparator
 
equals(Object) - Method in class com.linkedin.venice.utils.Pair
Deprecated.
 
equals(Object) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
equals(Object) - Method in class com.linkedin.venice.utils.VeniceProperties
 
EqualsRelationalOperator - Class in com.linkedin.venice.client.store.predicate
 
equalTo(String, Object) - Static method in class com.linkedin.venice.client.store.predicate.PredicateBuilder
 
error - Variable in class com.linkedin.venice.datarecovery.Command.Result
 
error - Variable in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
The first error founded during in`gestion
error(CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
error(CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, int, String, Exception) - Method in class com.linkedin.davinci.helix.StateModelIngestionProgressNotifier
 
error(String, int, String, Exception) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
error(String, int, String, Exception) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
error(String, int, String, Exception) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
error(String, int, String, Exception) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
error(String, int, String, Exception) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Report an error, during the consumption for a Partitions and store.
error(String, int, String, Exception) - Method in class com.linkedin.venice.utils.ExceptionCaptorNotifier
 
error(String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Message) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
error(MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
error(Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
ERROR - com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
 
ERROR - com.linkedin.venice.helix.HelixState
 
ERROR - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
ERROR - com.linkedin.venice.meta.VersionStatus
 
ERROR - com.linkedin.venice.pushmonitor.ExecutionStatus
Job/task met error when processing the data.
ERROR - com.linkedin.venice.status.protocol.enums.PushJobStatus
 
ERROR - com.linkedin.venice.status.PushJobDetailsStatus
 
ERROR - Static variable in class com.linkedin.alpini.consts.Level
The ERROR level designates error events that might still allow the application to continue running.
ERROR - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
ERROR_INT - Static variable in class com.linkedin.alpini.consts.Level
 
ERROR_PARTITION_AUTO_RESET_LIMIT - Static variable in class com.linkedin.venice.ConfigKeys
Maximum number of times controller will automatically reset an error partition for the current/serving version to mitigate impact of transient or long running issues during re-balance or restart.
ERROR_PARTITION_PROCESSING_CYCLE_DELAY - Static variable in class com.linkedin.venice.ConfigKeys
The delay between each cycle where we iterate over all applicable resources and their partition to reset error partitions and collect data on the effectiveness of previous resets.
ERROR_STATE - Static variable in enum com.linkedin.venice.helix.HelixState
 
ErrorCatchingHandler - Class in com.linkedin.venice.listener
Expects a GetRequestObject which has store name, key, and partition Queries the local store for the associated value writes the value (as a byte[]) back down the stack
ErrorCatchingHandler() - Constructor for class com.linkedin.venice.listener.ErrorCatchingHandler
 
ERRORCODE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
 
ERRORMESSAGE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
 
errorPartitionId - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Used for reporting error when the StoreIngestionTask.partitionConsumptionStateMap is empty
ErrorPartitionResetTask - Class in com.linkedin.venice.controller
A task that iterates over store version resources and reset error partitions if they meet the following criteria: The store version resource is the current version. The error partition only has exactly one error replica. For L/F model, using EV to check error replicas misses internal error replica states.
ErrorPartitionResetTask(String, HelixAdminClient, ReadOnlyStoreRepository, HelixExternalViewRepository, PushMonitor, MetricsRepository, int, long) - Constructor for class com.linkedin.venice.controller.ErrorPartitionResetTask
 
ErrorPartitionStats - Class in com.linkedin.venice.controller.stats
 
ErrorPartitionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.ErrorPartitionStats
 
errorReported - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether error has already been reported
errorReported() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
errorRequest(ServerHttpRequestStats, double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
errorType - Variable in exception com.linkedin.venice.exceptions.VeniceException
 
ErrorType - Enum in com.linkedin.venice.exceptions
ExceptionType enum did not have a default deserialization annotation and this makes it non-evolvable till all clients upgrade to newer versions.
escapeDelimiters(StringBuilder, CharSequence) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
 
escapedSplit(String, String, String) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
Splits a target string according to some substring (non-regex), which may be escaped in the target string.
EspressoFixedChannelPool - Class in com.linkedin.alpini.netty4.pool
Forked from Netty's FixedChannelPool {ChannelPool} implementation that takes another {ChannelPool} implementation and enforce a maximum number of concurrent connections.
EspressoFixedChannelPool(Bootstrap, ChannelPoolHandler, int) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
EspressoFixedChannelPool(Bootstrap, ChannelPoolHandler, int, int) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
EspressoFixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
Creates a new instance.
EspressoFixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
Creates a new instance.
EspressoFixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
Creates a new instance.
EspressoHttp2FrameCodec - Class in io.netty.handler.codec.http2
An extension of the Http2FrameCodec which provides a facility to be able to block stream creation from clients without incurring any cost of stream creation on the server side.
EspressoHttp2FrameCodecBuilder - Class in io.netty.handler.codec.http2
 
EspressoHttp2FrameCodecUtil - Class in io.netty.handler.codec.http2
Utility class to expose package private members.
EspressoHttp2MultiplexHandler - Class in io.netty.handler.codec.http2
Forked from Netty's Http2MultiplexHandler (4.1.42) (https://github.com/netty/netty/blob/4.1/codec-http2/src/main/java/io/netty/handler/codec/http2/Http2MultiplexHandler.java) In HTTP/1.1, the requests from the client are distributed across 48 workers threads of router.
EspressoHttp2MultiplexHandler(ChannelHandler) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
Creates a new instance
EspressoHttp2MultiplexHandler(ChannelHandler, boolean, boolean) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
EspressoHttp2MultiplexHandler(ChannelHandler, ChannelHandler) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
Creates a new instance
EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel - Class in io.netty.handler.codec.http2
 
EspressoHttp2StreamChannelBootstrap - Class in io.netty.handler.codec.http2
Forked from Netty 4 Http2StreamChannelBootstrap to allow using EspressoHttp2MultiplexHandler in the pipeline.
EspressoHttp2StreamChannelBootstrap(Channel) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
 
EspressoHttp2StreamChannelBootstrap(Channel, boolean) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
 
EspressoHttpObjectAggregator - Class in io.netty.handler.codec.http
Forked from Netty 4.1.42.Final.
EspressoHttpObjectAggregator(int) - Constructor for class io.netty.handler.codec.http.EspressoHttpObjectAggregator
Creates a new instance.
EspressoHttpObjectAggregator(int, boolean) - Constructor for class io.netty.handler.codec.http.EspressoHttpObjectAggregator
Creates a new instance.
EspressoHttpObjectEncoder<H extends io.netty.handler.codec.http.HttpMessage> - Class in io.netty.handler.codec.http
Forked from Netty 4.1.42.Final.
EspressoHttpObjectEncoder() - Constructor for class io.netty.handler.codec.http.EspressoHttpObjectEncoder
 
EspressoMessageAggregator<I,​S,​C extends io.netty.buffer.ByteBufHolder,​O extends io.netty.buffer.ByteBufHolder> - Class in io.netty.handler.codec
Forked from Netty 4.1.42.Final.
EspressoMessageAggregator(int) - Constructor for class io.netty.handler.codec.EspressoMessageAggregator
Creates a new instance.
EspressoMessageAggregator(int, Class<? extends I>) - Constructor for class io.netty.handler.codec.EspressoMessageAggregator
 
EspressoMessageToMessageDecoder<I> - Class in io.netty.handler.codec
Forked from Netty 4.1.42.Final.
EspressoMessageToMessageDecoder() - Constructor for class io.netty.handler.codec.EspressoMessageToMessageDecoder
Create a new instance which will try to detect the types to match out of the type parameter of the class.
EspressoMessageToMessageDecoder(Class<? extends I>) - Constructor for class io.netty.handler.codec.EspressoMessageToMessageDecoder
Create a new instance
EspressoMessageToMessageEncoder<I> - Class in io.netty.handler.codec
Forked from Netty 4.1.42.Final.
EspressoMessageToMessageEncoder() - Constructor for class io.netty.handler.codec.EspressoMessageToMessageEncoder
Create a new instance which will try to detect the types to match out of the type parameter of the class.
EspressoMessageToMessageEncoder(Class<? extends I>) - Constructor for class io.netty.handler.codec.EspressoMessageToMessageEncoder
Create a new instance
EspressoSimpleChannelPool - Class in com.linkedin.alpini.netty4.pool
Forked from Netty's SimpleChannelPool Simple ChannelPool implementation which will create new Channels if someone tries to acquire a Channel but none is in the pool atm.
EspressoSimpleChannelPool(Bootstrap, ChannelPoolHandler) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
EspressoSimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Creates a new instance.
EspressoSimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Creates a new instance.
EspressoSimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Creates a new instance.
ESTIMATE_DATA_RECOVERY_TIME - com.linkedin.venice.Command
 
EstimateDataRecoveryTimeCommand - Class in com.linkedin.venice.datarecovery
 
EstimateDataRecoveryTimeCommand() - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
EstimateDataRecoveryTimeCommand(EstimateDataRecoveryTimeCommand.Params) - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
EstimateDataRecoveryTimeCommand.Params - Class in com.linkedin.venice.datarecovery
 
EstimateDataRecoveryTimeCommand.Params.Builder - Class in com.linkedin.venice.datarecovery
 
EstimateDataRecoveryTimeCommand.Result - Class in com.linkedin.venice.datarecovery
 
estimateRecoveryTime(DataRecoveryClient.DataRecoveryParams, EstimateDataRecoveryTimeCommand.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
 
ETERNAL_TOPIC_RETENTION_ENABLED - Static variable in class com.linkedin.venice.views.ViewUtils
 
ETERNAL_TOPIC_RETENTION_POLICY_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
ETL_KEY_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
ETL_UNION_VALUE_WITH_NULL_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
ETL_UNION_VALUE_WITHOUT_NULL_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
ETL_VALUE_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
ETL_VALUE_SCHEMA_TRANSFORMATION - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
etlConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Properties related to ETL Store behavior.
ETLED_PROXY_USER_ACCOUNT - com.linkedin.venice.Arg
 
ETLED_PROXY_USER_ACCOUNT - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
etledUserProxyAccount - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
etledUserProxyAccount - Variable in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
etledUserProxyAccount - Variable in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
If enabled regular ETL or future version ETL, this account name is part of path for where the ETLed snapshots will go.
etlStoreConfig - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
ETLStoreConfig - Class in com.linkedin.venice.meta.systemstore.schemas
 
ETLStoreConfig - Interface in com.linkedin.venice.meta
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
ETLStoreConfig - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
ETLStoreConfig() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
Default constructor.
ETLStoreConfig(CharSequence, Boolean, Boolean) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
All-args constructor.
ETLStoreConfigImpl - Class in com.linkedin.venice.meta
A container of ETL Enabled Store related configurations.
ETLStoreConfigImpl() - Constructor for class com.linkedin.venice.meta.ETLStoreConfigImpl
 
ETLStoreConfigImpl(String, boolean, boolean) - Constructor for class com.linkedin.venice.meta.ETLStoreConfigImpl
 
ETLStoreConfigRecord - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
ETLStoreConfigRecord() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
Default constructor.
ETLStoreConfigRecord(CharSequence, Boolean, Boolean) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
All-args constructor.
ETLStoreConfigSerializerMixin(String, boolean, boolean) - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer.ETLStoreConfigSerializerMixin
 
ETLUtils - Class in com.linkedin.venice.etl
 
ETLUtils() - Constructor for class com.linkedin.venice.etl.ETLUtils
 
etlValueSchemaTransformation - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
ETLValueSchemaTransformation - Enum in com.linkedin.venice.etl
In ETL jobs, when a "delete" record is seen, "value" is set to "null" and "DELETED_TS" is set to the offset where this delete record was seen.
evaluate(GenericRecord) - Method in class com.linkedin.venice.client.store.predicate.AndPredicate
 
evaluate(GenericRecord) - Method in class com.linkedin.venice.client.store.predicate.EqualsRelationalOperator
 
evaluate(GenericRecord) - Method in interface com.linkedin.venice.client.store.predicate.Predicate
 
evaluateCompressionMetricCollectionEnabled(PushJobSetting, boolean) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
This functions evaluates the config PushJobSetting.compressionMetricCollectionEnabled based on the input data and other configs as an initial filter to disable this config for cases where we won't be able to collect this information or where it doesn't make sense to collect this information.
EventGroupLoopSupplier - Interface in com.linkedin.alpini.netty4.misc
Created by acurtis on 12/22/17.
eventLoopGroup() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
EventThrottler - Class in com.linkedin.venice.throttle
A class to throttle Events to a certain rate This class takes a maximum rate in events/sec and a minimum interval over which to check the rate.
EventThrottler(long) - Constructor for class com.linkedin.venice.throttle.EventThrottler
 
EventThrottler(long, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
 
EventThrottler(long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
 
EventThrottler(Time, long, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
 
EventThrottler(Time, LongSupplier, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
 
EventThrottler(LongSupplier, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
 
EventThrottlingStrategy - Interface in com.linkedin.venice.throttle
This interface is used to abstract the strategy to handle the quota exceeding case.
exceedQuota(long) - Method in class com.linkedin.venice.hadoop.InputStorageQuotaTracker
 
EXCEPTION_THROWN - com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
 
exceptionally(Function<Throwable, ? extends T>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
exceptionally(Function<Throwable, ? extends V>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
ExceptionCaptorNotifier - Class in com.linkedin.venice.utils
 
ExceptionCaptorNotifier() - Constructor for class com.linkedin.venice.utils.ExceptionCaptorNotifier
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
Handle the Throwable by logging and closing the Channel.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.Http2ExceptionHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
Calls ChannelHandlerContext.fireExceptionCaught(Throwable) to forward to the next ChannelHandler in the ChannelPipeline.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionReportHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.listener.ErrorCatchingHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.listener.RouterRequestHttpHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.AdminOperationsHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.HealthCheckHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.MetaDataHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.RouterThrottleHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
ExceptionClassAndCauseClassMatcher - Class in com.linkedin.venice.unit.matchers
 
ExceptionClassAndCauseClassMatcher(Class, Class) - Constructor for class com.linkedin.venice.unit.matchers.ExceptionClassAndCauseClassMatcher
 
ExceptionClassMatcher - Class in com.linkedin.venice.unit.matchers
 
ExceptionClassMatcher(Class) - Constructor for class com.linkedin.venice.unit.matchers.ExceptionClassMatcher
 
exceptionThrown - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
ExceptionType - Enum in com.linkedin.venice.exceptions
Deprecated.
since v0.2.620 Previously, this enum didn't have the @JsonEnumDefaultValue annotation. This annotation helps Jackson deserialize arbitrary values to a default value instead of throwing an Exception. Without this annotation, the enum is essentially non-evolvable since there may be many clients that are already running older code. Use ErrorType instead.
ExceptionUtil - Enum in com.linkedin.alpini.base.misc
 
ExceptionUtil.ExceptionThrower - Interface in com.linkedin.alpini.base.misc
 
ExceptionUtils - Class in com.linkedin.venice.utils
Static utility functions to deal with exceptions.
ExceptionUtils() - Constructor for class com.linkedin.venice.utils.ExceptionUtils
 
ExceptionWithResponseStatus - Exception in com.linkedin.alpini.netty4.misc
 
ExceptionWithResponseStatus(HttpResponseStatus) - Constructor for exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
ExceptionWithResponseStatus(HttpResponseStatus, String) - Constructor for exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
ExceptionWithResponseStatus(HttpResponseStatus, String, Throwable) - Constructor for exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
ExceptionWithResponseStatus(HttpResponseStatus, String, Throwable, boolean, boolean) - Constructor for exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
ExceptionWithResponseStatus(HttpResponseStatus, Throwable) - Constructor for exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
ExceptionWithResponseStatus(HttpResponseStatus, Throwable, boolean, boolean) - Constructor for exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
ExceptionWithStatus - Exception in com.linkedin.alpini.base.misc
 
ExceptionWithStatus(Class<STATUS>, STATUS, int, String) - Constructor for exception com.linkedin.alpini.base.misc.ExceptionWithStatus
 
ExceptionWithStatus(Class<STATUS>, STATUS, int, String, Throwable) - Constructor for exception com.linkedin.alpini.base.misc.ExceptionWithStatus
 
ExceptionWithStatus(Class<STATUS>, STATUS, int, String, Throwable, boolean, boolean) - Constructor for exception com.linkedin.alpini.base.misc.ExceptionWithStatus
 
exec(Class, String...) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
 
exec(Class, List<String>, List<String>) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
 
exec(Class, List<String>, List<String>, boolean) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
 
exec(Class, List<String>, List<String>, boolean, Optional<String>) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
 
exec(Class, List<String>, List<String>, String, boolean, Optional<String>) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
 
execute() - Method in class com.linkedin.venice.datarecovery.Command
 
execute() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
execute() - Method in class com.linkedin.venice.datarecovery.MonitorCommand
 
execute() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
execute() - Method in class com.linkedin.venice.system.store.ControllerClientBackedSystemSchemaInitializer
 
execute() - Method in interface com.linkedin.venice.utils.TestUtils.NonDeterministicAssertion
 
execute(int, Consumer<Integer>) - Method in class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
This method takes in customized logic for each subPartition number and be executed on every subPartition of the specified user partition.
execute(DataRecoveryClient.DataRecoveryParams, StoreRepushCommand.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
 
execute(DataValidationException) - Method in interface com.linkedin.davinci.validation.PartitionTracker.DIVErrorMetricCallback
 
execute(File, String, String...) - Static method in class com.linkedin.alpini.io.ExternalCommand
Executes the external command in the given working directory and waits for it to be finished.
execute(Runnable) - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
execute(Runnable) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Executes command with zero required delay.
execute(Runnable) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
execute(Runnable) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
execute(Runnable) - Method in class com.linkedin.alpini.router.impl.netty4.TimerTimeoutProcessor
 
execute(String) - Method in class com.linkedin.venice.controller.init.ClusterLeaderInitializationManager
 
execute(String) - Method in interface com.linkedin.venice.controller.init.ClusterLeaderInitializationRoutine
 
execute(String) - Method in class com.linkedin.venice.controller.init.DelegatingClusterLeaderInitializationRoutine
 
execute(String) - Method in class com.linkedin.venice.controller.init.PerClusterInternalRTStoreInitializationRoutine
 
execute(String) - Method in class com.linkedin.venice.controller.init.SharedInternalRTStoreInitializationRoutine
 
execute(String) - Method in class com.linkedin.venice.controller.init.SystemSchemaInitializationRoutine
 
execute(String, int) - Method in interface com.linkedin.davinci.kafka.consumer.TopicPartitionConsumerFunction
 
execute(Map<Integer, Schema>) - Method in class com.linkedin.venice.system.store.ControllerClientBackedSystemSchemaInitializer
 
execute(Set<K>) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
execute(Set<K>) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Send compute request to Venice, and this should be the last step of the compute specification.
EXECUTE_DATA_RECOVERY - com.linkedin.venice.Command
 
executeGet(String, String, QueryParams, Class<T>) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
executeGet(String, String, QueryParams, Class<T>, int) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
executePartitionConsumptionState(int, Consumer<PartitionConsumptionState>) - Method in class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
This method takes in customized logic and execute it on every subPartition's PartitionConsumptionState of the user partition.
executePost(String, String, QueryParams, Class<T>) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
executePost(String, String, QueryParams, Class<T>, int) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
executePost(String, String, QueryParams, Class<T>, int, byte[]) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
This method shoves the POST string query params into the URL so the body will only contain the byte array data to make processing/deserializing easier.
executeRequest(HttpRequestBase, Class<T>, int) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
executeShellCommand(String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
executeStateTransition(Message, NotificationContext, Runnable) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
executeStateTransition(Message, NotificationContext, Runnable, boolean) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
executeTask(Consumer<ChannelPromise>, ChannelFutureListener) - Method in class com.linkedin.alpini.netty4.misc.ChannelTaskSerializer
 
executeUnderConditionalLock(Runnable, BooleanSupplier, Object) - Static method in class com.linkedin.venice.utils.concurrent.ConcurrencyUtils
 
executeUnderLock(Runnable, Runnable, BooleanSupplier, Object) - Static method in class com.linkedin.venice.utils.concurrent.ConcurrencyUtils
 
executeWithFilter(Predicate, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
 
executeWithFilter(Predicate, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV4
 
executeWithFilter(Predicate, StreamingCallback<GenericRecord, GenericRecord>) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Streaming interface that sends compute request to Venice, which will be executed on values whose keys satisfy the given predicate.
executeWithMaxAttempt(VeniceCheckedRunnable, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Runnable with fixed delay with a maximum attempt.
executeWithMaxAttempt(VeniceCheckedRunnable, int, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Runnable with fixed delay with a maximum attempt.
executeWithMaxAttempt(VeniceCheckedSupplier<T>, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Supplier with fixed delay with a maximum attempt.
executeWithMaxAttempt(VeniceCheckedSupplier<T>, int, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Supplier with fixed delay with a maximum attempt.
executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedRunnable, int, Duration, Duration, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Runnable with exponential backoff.
executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedRunnable, int, Duration, Duration, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Runnable with exponential backoff.
executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedSupplier<T>, int, Duration, Duration, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Supplier with exponential backoff.
executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedSupplier<T>, int, Duration, Duration, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Supplier with exponential backoff.
executeWithMaxAttemptNoIntermediateLogging(VeniceCheckedRunnable, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Runnable with fixed delay with a maximum attempt.
executeWithMaxRetriesAndFixedAttemptDuration(VeniceCheckedSupplier<T>, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
Execute a Supplier with maximum retries and fix duration per retry attempt.
executeWithTimeout(File, String, long, String...) - Static method in class com.linkedin.alpini.io.ExternalCommand
Executes the external command in the given working directory and waits (until timeout is elapsed) for it to be finished.
executeWithTimeoutWithEnv(File, String, long, Map<String, String>, String...) - Static method in class com.linkedin.alpini.io.ExternalCommand
 
EXECUTION - com.linkedin.venice.Arg
 
EXECUTION - com.linkedin.venice.controllerapi.ControllerRoute
 
EXECUTION_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
executionId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
ID of a command execution which is used to query the status of this command.
ExecutionIdAccessor - Interface in com.linkedin.venice.controller
Accessor user to get/update the last execution id and the generated id from a storage.
ExecutionStatus - Enum in com.linkedin.venice.pushmonitor
Status of executing off-line push.
ExecutionStatusWithDetails - Class in com.linkedin.venice.pushmonitor
 
ExecutionStatusWithDetails(ExecutionStatus) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
 
ExecutionStatusWithDetails(ExecutionStatus, String) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
 
ExecutionStatusWithDetails(ExecutionStatus, String, boolean) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
 
ExecutionStatusWithDetails(ExecutionStatus, String, boolean, Long) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
 
executor() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
executor() - Method in class io.netty.bootstrap.PendingConnectPromise
 
executor(CHC) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
executor(ChannelHandlerContext) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
executor(Executor) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
executor(Executor) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
EXECUTOR_GROUP_ATTRIBUTE_KEY - Static variable in class com.linkedin.alpini.netty4.misc.NettyUtils
 
executorCount() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
Deprecated.
due to confusing name. Use ChannelPoolManager.subpoolCount()
executorCount() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
Deprecated.
executorCount() - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
Deprecated.
executorFailure(ChannelPromise, RejectedExecutionException) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
 
executorGroup(Channel) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
executorGroup(ChannelPipeline) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
Executors - Enum in com.linkedin.alpini.base.concurrency
Factory and utility methods for Executor, ExecutorService, ScheduledExecutorService, ThreadFactory, and Callable classes defined in this package.
executorService - Variable in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
ExecutorService - Interface in com.linkedin.alpini.base.concurrency
An analog to ExecutorService except that the futures returned are AsyncFutures.
existingHttpPipelineInitializer(Consumer<ChannelPipeline>) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
exists(ZkBaseDataAccessor<T>, String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
exit() - Method in class com.linkedin.alpini.log.FastLogger
 
exit() - Method in enum com.linkedin.venice.samza.SamzaExitMode
 
exit(String) - Static method in class com.linkedin.venice.utils.Utils
Print an error and exit with error code 1
exit(String, int) - Static method in class com.linkedin.venice.utils.Utils
Print an error and exit with the given error code
exit(R) - Method in class com.linkedin.alpini.log.FastLogger
 
exitValue() - Method in class com.linkedin.alpini.io.ExternalCommand
 
exitValue() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
 
EXPECTED_PROTOCOL - Static variable in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
EXPECTED_ROUTER_COUNT - com.linkedin.venice.Arg
 
EXPECTED_ROUTER_COUNT - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
Experimental - Annotation Type in com.linkedin.venice.annotation
 
ExpiringSet<T> - Class in com.linkedin.venice.utils
Created by mwise on 4/12/16.
ExpiringSet(long, TimeUnit) - Constructor for class com.linkedin.venice.utils.ExpiringSet
 
EXTENDED_INPUT_DATA_SCHEMA_VALIDATION_FAILED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
EXTENDED_SCHEMA_VALIDITY_CHECK_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
ExtendedResourcePathParser<P extends ResourcePath<K>,​K,​HTTP_REQUEST extends BasicRequest> - Interface in com.linkedin.alpini.router.api
Created by acurtis on 6/12/17.
extendedSchemaValidityCheckEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
ExternalCommand - Class in com.linkedin.alpini.io
This class encapsulates a java Process to handle properly output and error and preventing potential deadlocks.
ExternalCommand(ProcessBuilder) - Constructor for class com.linkedin.alpini.io.ExternalCommand
Constructor
EXTERNALVIEW - com.linkedin.venice.helix.HelixViewPropertyType
 
extinguish() - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
EXTRA_COMMAND_ARGS - com.linkedin.venice.Arg
 
extract(byte[], Iterator<byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
extract(byte[], Iterator<byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
extractAvroSubSchema(Schema, String) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
extractAvroSubSchema(Schema, String) - Method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
 
extractAvroSubSchema(Schema, String) - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
 
extractByteArray(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
 
extractByteArray(ByteBuffer, byte[], int, int) - Static method in class com.linkedin.venice.utils.ByteUtils
Extract the data in the ByteBuffer into the destination array by copying "length" bytes from the source buffer into the given array, starting at the current position of the source buffer and at the given offset in the destination array.
extractClientCert(ServerCall<?, ?>) - Method in class com.linkedin.venice.acl.handler.StoreAclHandler
 
extractClientCert(ChannelHandlerContext) - Method in class com.linkedin.venice.acl.handler.StoreAclHandler
 
extractClientCert(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.ServerStoreAclHandler
 
extractOffsetVectorFromMessage(int, ByteBuffer) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
extractOffsetVectorFromRmd(GenericRecord) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
 
extractOffsetVectorSumFromRmd(GenericRecord) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
 
extractQueryParameters(HttpRequest) - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
We provide this method as a utility function as opposed to storing the query parameters in this class.
extractQueryParamsFromRequest(Map<String, String[]>, ControllerResponse) - Static method in class com.linkedin.venice.utils.Utils
 
extractRegularStoreName(String) - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
This function is to extract the regular store name from the system store name.
extractSslHandler(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.ServerConnectionStatsHandler
 
extractSslHandler(ChannelHandlerContext) - Static method in class com.linkedin.venice.listener.ServerHandlerUtils
 
extractStoreName(String) - Method in class com.linkedin.venice.acl.handler.StoreAclHandler
Extract the store name from the incoming resource name.
extractStoreName(String) - Method in class com.linkedin.venice.listener.ServerStoreAclHandler
In Venice Server, the resource name is actually a Kafka topic name.
extractSystemStoreType(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
extractTempRMDSSTFileNo(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
extractTempSSTFileNo(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
extractTimestampFromRmd(GenericRecord) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
 
extractUserStoreName(String) - Static method in enum com.linkedin.venice.common.VeniceSystemStoreType
Extract the corresponding user store name from the given store name if it happens to be a system store.
extractVersionTopicsToCleanup(Admin, Map<PubSubTopic, Long>, int, int) - Static method in class com.linkedin.venice.controller.kafka.TopicCleanupService
Filter Venice version topics so that the returned topics satisfying the following conditions: topic is truncated based on retention time.

F

FABRIC - com.linkedin.venice.Arg
 
FABRIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
FABRIC_A - com.linkedin.venice.Arg
 
FABRIC_A - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
FABRIC_B - com.linkedin.venice.Arg
 
FABRIC_B - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
factory() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
factory(Class<F>) - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Return a factory which implements the requested factory class F.
factory(Class<F>) - Method in class com.linkedin.alpini.base.test.ResourceRegistryTestBase
 
factory(Class<F>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
failed(Throwable) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Create a new failed future.
FAILED - com.linkedin.venice.hadoop.jobs.ComputeJob.Status
A job that failed during it's execution
FAILED - com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
 
FAILED - com.linkedin.venice.utils.VeniceResourceCloseResult
 
FAILED_HEALTH_CHECK - Static variable in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
 
FAILED_VERIFICATION - com.linkedin.venice.hadoop.jobs.ComputeJob.Status
A job that has completed execution but failed verification
FailedAsyncFuture<T> - Class in com.linkedin.alpini.base.concurrency.impl
 
FailedAsyncFuture(Throwable) - Constructor for class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
failedLockAcquisition - Variable in class com.linkedin.venice.stats.VeniceLockStats
 
failureDetails - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
failureString(String) - Method in class com.linkedin.venice.controller.AuditInfo
 
FakeCompressingSchema - Class in com.linkedin.venice.compression.protocol
This record is only used to training a ZSTD dictionary on a small amount of generated avro data
FakeCompressingSchema() - Constructor for class com.linkedin.venice.compression.protocol.FakeCompressingSchema
Default constructor.
FakeCompressingSchema(Integer, CharSequence) - Constructor for class com.linkedin.venice.compression.protocol.FakeCompressingSchema
All-args constructor.
FALSE - Static variable in interface com.linkedin.venice.utils.lazy.Lazy
 
FAST_AVRO_FIELD_LIMIT_PER_METHOD - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the maximum number of fields per method in a fast-avro generated deserializer.
FastAvroGenericDeserializer<V> - Class in com.linkedin.venice.serializer
* This class is leveraging linkedin-avro-fastserde-impl to speed up deserialization.
FastAvroGenericDeserializer(Schema, Schema, FastSerdeCache) - Constructor for class com.linkedin.venice.serializer.FastAvroGenericDeserializer
 
FastAvroSerializer<K> - Class in com.linkedin.venice.serializer
This class is leveraging linkedin-avro-fastserde-impl to speed up serialization, and so far it doesn't work for Avro-1.4, and it will fail back to regular Avro.
FastAvroSerializer(Schema, FastSerdeCache) - Constructor for class com.linkedin.venice.serializer.FastAvroSerializer
 
FastAvroSerializer(Schema, FastSerdeCache, boolean) - Constructor for class com.linkedin.venice.serializer.FastAvroSerializer
 
FastAvroSpecificDeserializer<T extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.serializer
This class is leveraging linkedin-avro-fastserde-impl to speed up deserialization.
FastAvroSpecificDeserializer(Schema, Class<T>, FastSerdeCache) - Constructor for class com.linkedin.venice.serializer.FastAvroSpecificDeserializer
 
FASTCLIENT_HTTP_VARIANTS - Static variable in class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
FastClientStats - Class in com.linkedin.venice.fastclient.stats
 
FastDeserializerGeneratorAccessor - Class in com.linkedin.avro.fastserde
Only for the sake of accessing a package-private method...
FastDeserializerGeneratorAccessor() - Constructor for class com.linkedin.avro.fastserde.FastDeserializerGeneratorAccessor
 
FASTER_OF_TWO_ONLINE - com.linkedin.venice.meta.ReadStrategy
 
FastFixedChannelPool - Class in com.linkedin.alpini.netty4.pool
Forked from Netty's FixedChannelPool {ChannelPool} implementation that takes another {ChannelPool} implementation and enforce a maximum number of concurrent connections.
FastFixedChannelPool(Bootstrap, ChannelPoolHandler, int) - Constructor for class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
FastFixedChannelPool(Bootstrap, ChannelPoolHandler, int, int) - Constructor for class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
FastFixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int) - Constructor for class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Creates a new instance.
FastFixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Creates a new instance.
FastFixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Creates a new instance.
FastFixedChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, IntSupplier, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
Creates a new instance.
FastFixedChannelPool.PoolChannelGroup - Class in com.linkedin.alpini.netty4.pool
 
FastLog - Class in com.linkedin.alpini.log
 
FastLog() - Constructor for class com.linkedin.alpini.log.FastLog
 
FastLogContext - Class in com.linkedin.alpini.log
 
FastLogContext(FastLogMBean, LoggerContext) - Constructor for class com.linkedin.alpini.log.FastLogContext
 
FastLogContextFactory - Class in com.linkedin.alpini.log
An alternate Log4j2 LoggerContextFactory implementation which returns loggers which can short-circuit debug and trace messages so that they may be disabled without incurring cost from filters installed within Log4j.
FastLogContextFactory() - Constructor for class com.linkedin.alpini.log.FastLogContextFactory
 
FastLogContextFactory(LoggerContextFactory) - Constructor for class com.linkedin.alpini.log.FastLogContextFactory
 
FastLogger - Class in com.linkedin.alpini.log
 
FastLogger(FastLogContext, ExtendedLogger) - Constructor for class com.linkedin.alpini.log.FastLogger
 
FastLogMBean - Interface in com.linkedin.alpini.log
 
FastSerializerDeserializerFactory - Class in com.linkedin.venice.serializer
 
FastSerializerDeserializerFactory() - Constructor for class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
 
FastSimpleChannelPool - Class in com.linkedin.alpini.netty4.pool
Forked from Netty's SimpleChannelPool Simple ChannelPool implementation which will create new Channels if someone tries to acquire a Channel but none is in the pool atm.
FastSimpleChannelPool(Bootstrap, ChannelPoolHandler) - Constructor for class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Creates a new instance using the ChannelHealthChecker.ACTIVE.
FastSimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker) - Constructor for class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Creates a new instance.
FastSimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Creates a new instance.
FastSimpleChannelPool(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, boolean, int) - Constructor for class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Creates a new instance.
fatal(CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Message) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
fatal(Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
FATAL_DATA_VALIDATION_ERROR - Static variable in class com.linkedin.venice.utils.Utils
 
FATAL_DATA_VALIDATION_FAILURE_TOPIC_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
FatalDataValidationException - Exception in com.linkedin.venice.exceptions.validation
This class encompasses all error conditions which: 1.
FatalDataValidationException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.FatalDataValidationException
 
FatalDataValidationException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.validation.FatalDataValidationException
 
FCFS - com.linkedin.alpini.base.queuing.QOSPolicy
 
fetch() - Method in class com.linkedin.venice.ControlMessageDumper
1.
fetchAndProcess() - Method in class com.linkedin.venice.KafkaTopicDumper
1.
fetchLastBytesOf(Channel, int) - Static method in class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler
 
fetchRmdSchemas() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
Fetch all rmd schemas under the HDFSSchemaSource.rmdSchemaDir if available.
fetchRmdSchemas() - Method in interface com.linkedin.venice.hadoop.schema.SchemaSource
 
fetchValueSchemas() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
Fetch all value schemas under the HDFSSchemaSource.rmdSchemaDir if available.
fetchValueSchemas() - Method in interface com.linkedin.venice.hadoop.schema.SchemaSource
 
field - Variable in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
The field in the original value record, which will used to execute cosine-similarity calculation
field - Variable in class com.linkedin.venice.compute.protocol.request.Count
The field name in the original value record of type array or map, which will used to execute count operation on
field - Variable in class com.linkedin.venice.compute.protocol.request.DotProduct
The field in the original value record, which will used to execute dot-product calculation
field - Variable in class com.linkedin.venice.compute.protocol.request.HadamardProduct
The field in the original value record, which will used to execute hadamard-product calculation
FILE_KEY_SCHEMA - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
FILE_VALUE_SCHEMA - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
fillInStackTrace() - Method in exception com.linkedin.alpini.base.misc.Http2TooManyStreamsException
 
filter(Predicate<? super C>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
filter(Predicate<? super T>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
If a value is initialized, and the value matches the given predicate, return an Optional describing the value, otherwise return an empty Optional.
filter(Predicate<? super T>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
filter(Iterator<T>, Predicate<? super T>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
filterCanonicalizedSchemas(SchemaEntry, Collection<SchemaEntry>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Filter the given schemas using the referenceSchema and AvroCompatibilityHelper.
FilterChain<INPUT_VALUE> - Class in com.linkedin.venice.hadoop
The FilterChain class takes a list of AbstractVeniceFilter to assemble a filter chain to manage the life cycles' of filters and perform filtering based on the order of filters.
FilterChain() - Constructor for class com.linkedin.venice.hadoop.FilterChain
 
FilterChain(AbstractVeniceFilter<INPUT_VALUE>...) - Constructor for class com.linkedin.venice.hadoop.FilterChain
 
filterDisallowedCiphersuites(String[]) - Static method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
filterDisallowedCiphersuites(String[]) - Static method in class com.linkedin.venice.security.DefaultSSLFactory
 
FilteringPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
A PollStrategy implementation which can pluck out records from the stream.
FilteringPollStrategy(AbstractPollStrategy, Set<PubSubTopicPartitionOffset>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.FilteringPollStrategy
 
filterSchemas(SchemaEntry, Collection<SchemaEntry>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Filter the given schemas using the referenceSchema and the underlying Schema.equals method.
finalizeExpectedChecksum() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
finalSegment - Variable in class com.linkedin.venice.kafka.protocol.EndOfSegment
This field is set to true when the producer knows that there is no more data coming from its data source after this EndOfSegment.
find(D2TransportClient, String) - Method in class com.linkedin.venice.client.store.D2ServiceDiscovery
 
find(D2TransportClient, String, boolean) - Method in class com.linkedin.venice.client.store.D2ServiceDiscovery
 
find(ControllerClient, PubSubConsumerAdapter, String, String, long, long, long) - Static method in class com.linkedin.venice.TopicMessageFinder
 
find(String) - Method in interface com.linkedin.venice.utils.PathResourceRegistry
 
find(String) - Method in class com.linkedin.venice.utils.TrieBasedPathResourceRegistry
 
findAllBootstrappingVersions(String) - Method in interface com.linkedin.venice.controller.Admin
Find the store versions which have at least one bootstrap replica.
findAllBootstrappingVersions(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
findAllBootstrappingVersions(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
findFoldersWithFileExtension(File, String) - Static method in class com.linkedin.venice.utils.TestUtils
 
findHosts(String, String, String, int, HostHealthMonitor<Instance>) - Method in class com.linkedin.venice.router.api.VeniceHostFinder
 
findHosts(String, String, String, HostHealthMonitor<Instance>, VeniceRole) - Method in class com.linkedin.venice.router.api.VeniceHostFinder
This parameter list is based on the router API.
findHosts(String, String, String, HostHealthMonitor<H>, R) - Method in interface com.linkedin.alpini.router.api.HostFinder
Find hosts that can serve the given database and partition with one of the roles passed.
findPartitioner(String, int) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
Query the map to find the partitioner in need.
findPartitionName(Pair<String, K>) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
 
findPartitionName(String, RouterKey) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
 
findPartitionName(String, K) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
Returns the name of partition for the given key within the given table.
findPartitionName(String, K) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
Returns the name of partition for the given key within the given table.
findPartitionName(String, K) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
findPartitionNumber(RouterKey, int, String, int) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
 
findPartitionNumber(K, int, String, int) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
Venice-specific API for finding the partition number without the added overhead of parsing a partition name.
findPartitionNumber(K, int, String, int) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
Venice-specific API for finding the partition number without the added overhead of parsing a partition name.
findStartedAndCompletedStatus() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
finish() - Method in class com.linkedin.venice.compression.ReusableGzipOutputStream
Finishes writing compressed data to the output stream without closing the underlying stream.
finishAggregation(FullHttpMessage) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
finishAggregation(O) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Invoked when the specified aggregated message is about to be passed to the next handler in the pipeline.
finishRequest(long, int) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
 
finishRequest(long, int) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupRoundRobinStrategy
 
finishRequest(long, int) - Method in interface com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategy
Notify the corresponding Helix Group that the request is completed, and the implementation will decide whether any cleanup is required or not.
finishRequest(long, int) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
first() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
first() - Method in enum com.linkedin.venice.Arg
 
fiveBoolean() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
FixedChannelPoolFactory - Class in com.linkedin.alpini.netty4.pool
This factory constructs instances of FixedChannelPool for the ChannelPoolManager.
FixedChannelPoolFactory(Bootstrap, long, int, int, boolean, long, ChannelHealthChecker, CallTracker) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
FixedChannelPoolFactory(Bootstrap, long, int, int, boolean, long, ChannelHealthChecker, Function<SocketAddress, CallTracker>) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
FixedChannelPoolFactory(Bootstrap, long, int, int, int, boolean, long, ChannelHealthChecker, Function<SocketAddress, CallTracker>) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
FixedChannelPoolFactory(Bootstrap, long, IntSupplier, IntSupplier, IntSupplier, boolean, LongSupplier, ChannelHealthChecker, Function<SocketAddress, CallTracker>) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
FixedChannelPoolImpl - Class in com.linkedin.alpini.netty4.pool
Created by acurtis on 5/8/18.
FixedChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, int, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
FixedChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, int, boolean, boolean, BooleanSupplier) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
FixedChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, IntSupplier, int, int, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
FixedChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, IntSupplier, int, int, boolean, boolean, BooleanSupplier) - Constructor for class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
FixedFastChannelPoolImpl - Class in com.linkedin.alpini.netty4.pool
Created by acurtis on 5/8/18.
FixedFastChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
FixedFastChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, int, int, int, boolean, int, BooleanSupplier) - Constructor for class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
FixedFastChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, IntSupplier, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
FixedFastChannelPoolImpl(Bootstrap, ChannelPoolHandler, ChannelHealthChecker, FixedChannelPool.AcquireTimeoutAction, long, IntSupplier, int, int, boolean, int, BooleanSupplier) - Constructor for class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
FixedFastChannelPoolImpl.FixedPoolChannelGroup - Class in com.linkedin.alpini.netty4.pool
 
FixedPoolChannelGroup(String) - Constructor for class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl.FixedPoolChannelGroup
 
fixMalformedMetricName(String) - Static method in class com.linkedin.venice.stats.TehutiUtils
A valid metric name needs to pass the test in ObjectName.
fixMissingFields() - Method in class com.linkedin.venice.meta.AbstractStore
 
fixMissingFields() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
fixMissingFields() - Method in interface com.linkedin.venice.meta.Store
 
fixRetryRequestForSubPath(Map<RouterKey, ComputeRouterRequestKeyV1>) - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
If the parent request is a retry request, the sub-request generated by scattering-gathering logic should be retry request as well.
fixRetryRequestForSubPath(Map<RouterKey, MultiGetRouterRequestKeyV1>) - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
If the parent request is a retry request, the sub-request generated by scattering-gathering logic should be retry request as well.
fixRetryRequestForSubPath(Map<RouterKey, K>) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
FLAT_JSON - com.linkedin.venice.Arg
 
flatMap(Function<? super C, Optional<U>>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
flatMap(Function<? super T, Optional<U>>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
If a value is initialized, apply the provided Optional-bearing mapping function to it, return that result, otherwise return an empty Optional.
flatMap(Function<? super T, Optional<U>>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
flatMap(Iterator<T>, Function<? super T, Iterator<? extends R>>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
FLOAT32 - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
FLOAT64 - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
floor(E) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
floor(SortedSet<LongQuantileEstimation.Sample>, LongQuantileEstimation.Sample) - Method in class com.linkedin.alpini.base.statistics.LongQuantileArrayEstimation
 
floor(SortedSet<LongQuantileEstimation.Sample>, LongQuantileEstimation.Sample) - Method in class com.linkedin.alpini.base.statistics.LongStatsArrayAggregator
 
floor(SortedSet<SAMPLE>, SAMPLE) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
flush() - Method in class com.linkedin.alpini.io.CompressOutputStream
Flushes this output stream and forces any buffered output bytes to be written out to the stream.
flush() - Method in class com.linkedin.alpini.io.PigzOutputStream
Flushes this output stream and forces any buffered output bytes to be written out to the stream.
flush() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
 
flush() - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
 
flush() - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
 
flush() - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
 
flush() - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
flush() - Method in class com.linkedin.venice.writer.VeniceWriter
Call flush on the internal PubSubProducerAdapter.
flush(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
flush(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.OutboundByteBufAggregator
 
flush(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
flush(ChannelHandlerContext) - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
 
flush(String) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
Flushing the data to Venice store in case VeniceSystemProducer buffers message.
FnvHashFunction - Class in com.linkedin.alpini.base.hash
Forked from com.linkedin.databus.core.util @ r293057
FnvHashFunction() - Constructor for class com.linkedin.alpini.base.hash.FnvHashFunction
 
FOLLOWER_BYTES_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
FOLLOWER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
FOLLOWER_RECORDS_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
FORCE - com.linkedin.venice.Arg
 
FORCE_LEADER_ERROR_REPLICA_FAIL_OVER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Config to enable single leader replica disabling.
forceAddVersion(Version, boolean) - Method in class com.linkedin.venice.meta.AbstractStore
 
forceAddVersion(Version, boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
forceAddVersion(Version, boolean) - Method in interface com.linkedin.venice.meta.Store
 
ForceCloseOnWriteTimeoutHandler - Class in io.netty.handler.timeout
If a remote peer is unresponsive due to CPU throttling, GC or otherwise, ForceCloseOnWriteTimeoutHandler closes the connection on write timeout, the time out by default is 30 sec.
ForceCloseOnWriteTimeoutHandler(int) - Constructor for class io.netty.handler.timeout.ForceCloseOnWriteTimeoutHandler
 
forceStart() - Method in class com.linkedin.venice.d2.D2Server
Manually start the d2 server.
forceStart() - Method in class com.linkedin.venice.d2.D2ServerManager
 
forceStorageEngineCleanup(String) - Method in class com.linkedin.davinci.storage.StorageService
This function is used to forcely clean up all the databases belonging to {@param kafkaTopic}.
forClient() - Static method in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecBuilder
Creates a builder for an HTTP/2 client.
forEach(BiConsumer<? super K, ? super V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
forEach(Consumer<? super E>) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
forEach(Consumer<? super E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
forEachBeforeChunkAggregator(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
forEachBeforeHttpRequestHandler(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
forEachBeforeHttpServerCodec(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
forEachBeforeIdleStateHandler(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
forEachByte(int, int, ByteProcessor) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Iterates over the specified area of this buffer with the specified processor in ascending order.
forEachByte(ByteProcessor) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Iterates over the readable bytes of this buffer with the specified processor in ascending order.
forEachByteDesc(int, int, ByteProcessor) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Iterates over the specified area of this buffer with the specified processor in descending order.
forEachByteDesc(ByteProcessor) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Iterates over the readable bytes of this buffer with the specified processor in descending order.
forEachMessage(TouchTimer.Visitor) - Method in class com.linkedin.alpini.base.misc.TouchTimer
Visit all the messages for this TouchTimer
forField(Class<? super T>, String) - Static method in interface com.linkedin.alpini.base.misc.TypedFieldAccessor
 
forField(Field) - Static method in class com.linkedin.alpini.base.misc.SlowFieldAccessor
 
forField(Field) - Method in class com.linkedin.alpini.base.misc.SlowFieldAccessorHelper
 
forField(Field) - Static method in interface com.linkedin.alpini.base.misc.TypedFieldAccessor
 
forField(Field) - Method in class com.linkedin.alpini.base.misc.TypedFieldAccessorHelper
 
FORKED_PROCESS_METADATA_FILENAME - Static variable in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
ForkedJavaProcess - Class in com.linkedin.venice.utils
Adapted from https://stackoverflow.com/a/723914/791758
ForkedJavaProcess.LogInfo - Class in com.linkedin.venice.utils
 
format(Object) - Static method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
FORMAT_KEY - Static variable in class com.linkedin.venice.RequestConstants
 
formatDate(Date) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
 
formatDatetime(long) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Format the given date in a human readable form.
formatDatetime(Date) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Format the given date in a human readable form.
formatTimespan(long) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Format the given number of milliseconds in a more human readable form.
formatTimespan(long, StringBuilder) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Format the given number of milliseconds in a more human readable form and append it to the given StringBuilder.
formatTo(StringBuilder) - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
formatTo(StringBuilder) - Method in class com.linkedin.alpini.base.misc.Msg
 
formatTo(StringBuilder) - Method in class com.linkedin.alpini.base.misc.TouchTimer
 
formatTo(StringBuilder) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantile
 
formatTo(StringBuilder) - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
formatTo(StringBuilder) - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
forServer() - Static method in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecBuilder
Creates a builder for a HTTP/2 server.
FORWARD - com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
Clients using the old schema should be able to read data written with the new schema.
fourBoolean() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
FRAME_STREAM_KEY - Static variable in class com.linkedin.alpini.netty4.misc.Http2Utils
 
frameStream(AttributeMap) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
freeze() - Static method in enum com.linkedin.alpini.base.misc.Time
 
freeze(long, long) - Static method in enum com.linkedin.alpini.base.misc.Time
 
FREEZE_INGESTION_IF_READY_TO_SERVE_OR_LOCAL_DATA_EXISTS - Static variable in class com.linkedin.venice.ConfigKeys
This config will determine whether live update will be suppressed.
freezeIngestionIfReadyToServeOrLocalDataExists() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
fromBase64(String) - Static method in class com.linkedin.venice.router.api.RouterKey
 
fromDisplay(String) - Static method in enum com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
fromHexString(String) - Static method in class com.linkedin.venice.utils.ByteUtils
Translate the given hexidecimal string into a byte array
fromHostAndPort(String, int) - Static method in class com.linkedin.venice.meta.Instance
 
fromInt(int) - Static method in enum com.linkedin.venice.meta.BackupStrategy
 
fromInt(int) - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
fromNodeId(String) - Static method in class com.linkedin.venice.meta.Instance
 
fromPartitionStatus(PartitionStatus) - Static method in class com.linkedin.venice.pushmonitor.ReadOnlyPartitionStatus
 
fromProps(VeniceProperties) - Static method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroRecordReader
 
fromSchema(Schema) - Static method in enum com.linkedin.venice.etl.ETLValueSchemaTransformation
 
fromSchemaStr(String) - Static method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
fromStore(Store) - Static method in class com.linkedin.venice.meta.StoreInfo
 
fromString(String) - Static method in class com.linkedin.venice.router.api.RouterKey
 
fromTransportClientWithRoute(TransportClientResponse, String, CompletableFuture<Integer>) - Static method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
 
FROZEN - com.linkedin.venice.controllerapi.routes.V1Put
 
FROZEN - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
FULL - com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
Both backward and forward compatible.
FULL_PUSH - com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
 
FullHttpMultiPart - Interface in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/22/17.
FullHttpMultiPartRequest - Interface in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/27/17.
FULLLY_REPLICATED - com.linkedin.venice.meta.StoreStatus
 
FusedSslHandler - Class in com.linkedin.alpini.netty4.ssl
An implementation of SslHandler which limits the number of objects held within the pendingUnencryptedWrites queue.
FusedSslHandler(SSLEngine) - Constructor for class com.linkedin.alpini.netty4.ssl.FusedSslHandler
 
FusedSslHandler(SSLEngine, Executor) - Constructor for class com.linkedin.alpini.netty4.ssl.FusedSslHandler
 
FusedSslHandler.OverflowException - Exception in com.linkedin.alpini.netty4.ssl
 
FUTURE_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
FUTURE_VERSION_ETL_ENABLED - com.linkedin.venice.Arg
 
FUTURE_VERSION_ETL_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
Futures - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 2/1/17.
futureVersionETLEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
futureVersionETLEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
futureVersionETLEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Whether or not enable future version ETL - the version that might come online in future - for this store.

G

g() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.AbstractSample
 
gatewayTimeout() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
gatewayTimeout() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
GENERAL_ERROR - com.linkedin.venice.exceptions.ErrorType
 
GENERAL_ERROR - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
GENERATE_PARTIAL_UPDATE_RECORD_FROM_INPUT - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
generateComputeRequest(SchemaAndToString, boolean) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
GeneratedSchemaEntry - Class in com.linkedin.venice.schema
This is an abstract class which represents a generic class associating a generated schema id with it's corresponding value schema id
GeneratedSchemaEntry(int, int, byte[]) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaEntry
 
GeneratedSchemaEntry(int, int, String) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaEntry
 
GeneratedSchemaEntry(int, int, Schema) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaEntry
 
GeneratedSchemaID - Class in com.linkedin.venice.schema
In Venice, some schemas are generated, by deriving them from value schemas.
GeneratedSchemaID(int, int) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaID
 
generateHeartbeatMessage(CheckSumType) - Static method in class com.linkedin.venice.writer.VeniceWriter
 
generateHumanReadableByteCountString(long) - Static method in class com.linkedin.venice.utils.ByteUtils
Convert bytes to "Human-readable" output.
generateInput(int, boolean, int, AvroSerializer) - Static method in class com.linkedin.venice.utils.TestUtils
 
generateMessageId() - Static method in class com.linkedin.venice.status.StatusMessage
 
generateMetadataMap(long, long, long) - Static method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
 
generateMetadataSchema(String) - Method in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
generateMetadataSchema(String, int) - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
 
generateMetadataSchema(Schema) - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
Generate the latest replication metadata schema.
generateMetadataSchema(Schema) - Method in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
generateMetadataSchema(Schema, int) - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
 
generateMetadataSchemaFromRecord(Schema, String) - Method in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
generatePartialUpdateRecordFromInput - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
generateRePushId(String) - Static method in interface com.linkedin.venice.meta.Version
 
generateRequestId(HttpMethod, String, long, long) - Static method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
generateSchemaWithNamespace(String, String) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Generate a new schema based on the provided schema string with the namespace specified by {@param namespace}.
generateSupersetSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
 
generateSupersetSchema(Schema, Schema) - Method in interface com.linkedin.venice.controller.supersetschema.SupersetSchemaGenerator
Generate the superset schema based on two schemas.
generateSupersetSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
 
generateSuperSetSchema(Schema, Schema) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
Generate super-set schema of two Schemas.
generateSupersetSchemaFromAllValueSchemas(Collection<SchemaEntry>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
 
generateSupersetSchemaFromSchemas(Collection<SchemaEntry>) - Method in class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
 
generateSupersetSchemaFromSchemas(Collection<SchemaEntry>) - Method in interface com.linkedin.venice.controller.supersetschema.SupersetSchemaGenerator
Function to generate a superset based on all the input schemas.
generateSupersetSchemaFromSchemas(Collection<SchemaEntry>) - Method in class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
 
generateSystemStoreAclBinding(AclBinding) - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
Generate the corresponding AclBinding for a given Venice system store type based on the corresponding Venice store's Read acl.
GENERIC_EXCEPTION - Static variable in interface com.linkedin.alpini.base.monitoring.CallTracker
 
GenericChunkingAdapter<V extends org.apache.avro.generic.GenericRecord> - Class in com.linkedin.davinci.storage.chunking
Read compute and write compute chunking adapter
GenericChunkingAdapter() - Constructor for class com.linkedin.davinci.storage.chunking.GenericChunkingAdapter
Singleton
GenericQuantileEstimation<T> - Class in com.linkedin.alpini.base.statistics
 
GenericQuantileEstimation(double, int, Comparator<T>) - Constructor for class com.linkedin.alpini.base.statistics.GenericQuantileEstimation
 
GenericQuantileEstimation.Sample<T> - Class in com.linkedin.alpini.base.statistics
 
GenericRecordChunkingAdapter - Class in com.linkedin.davinci.storage.chunking
Just for the sake of casting the generic type to GenericRecord...
GenericRecordChunkingAdapter() - Constructor for class com.linkedin.davinci.storage.chunking.GenericRecordChunkingAdapter
Singleton
get() - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
get() - Method in class com.linkedin.alpini.base.concurrency.ComplexAccumulator
Returns the current sum.
get() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
Returns the current sum.
get() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Waits if necessary for the computation to complete, and then retrieves its result.
get() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Waits if necessary for the computation to complete, and then retrieves its result.
get() - Method in class com.linkedin.alpini.base.concurrency.Lazy
 
get() - Method in class com.linkedin.alpini.base.concurrency.ThreadedAccumulator
 
get() - Method in class com.linkedin.alpini.base.misc.Msg
 
get() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
get() - Method in class com.linkedin.alpini.base.misc.SoftThreadLocal
Returns the value in the current thread's copy of this thread-local variable.
get() - Method in interface com.linkedin.davinci.store.rocksdb.RocksDBThrottler.RocksDBSupplier
 
get() - Method in class com.linkedin.venice.hadoop.spark.input.VeniceAbstractPartitionReader
 
get() - Method in class com.linkedin.venice.utils.ByteArray
 
get() - Method in class com.linkedin.venice.utils.concurrent.CloseableThreadLocal
Returns the value in the current thread's copy of this thread-local variable.
get() - Method in class com.linkedin.venice.utils.ConcurrentRef
 
get() - Method in interface com.linkedin.venice.utils.lazy.Lazy
 
get() - Method in class com.linkedin.venice.utils.lazy.LazyImpl
Returns the object wrapped by this instance.
get() - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
get() - Method in interface com.linkedin.venice.utils.pools.ObjectPool
 
get() - Method in class com.linkedin.venice.utils.ReferenceCounted
 
get() - Method in interface com.linkedin.venice.utils.VeniceCheckedSupplier
 
get(byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Get a value from the partition database
get(byte[]) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
get(byte[]) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
get(byte[]) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
get(byte[]) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
get(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
get(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
get(int) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantiles
 
get(int) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
get(int) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
get(int) - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
get(int) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
get(int) - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
get(int) - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
 
get(int) - Method in class com.linkedin.venice.client.store.schemas.TestKeyRecord
 
get(int) - Method in class com.linkedin.venice.client.store.schemas.TestValueRecord
 
get(int) - Method in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
get(int) - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.Count
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
get(int) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
get(int) - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
get(int) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
get(int) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
get(int) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
get(int) - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
get(int) - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
get(int) - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.Delete
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.Put
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.Update
 
get(int) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
get(int) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
get(int) - Method in class com.linkedin.venice.metadata.response.VersionProperties
 
get(int) - Method in class com.linkedin.venice.participant.protocol.KillPushJob
 
get(int) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
get(int) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
get(int) - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
get(int) - Method in class com.linkedin.venice.pushstatus.PushStatusKey
 
get(int) - Method in class com.linkedin.venice.pushstatus.PushStatusValue
 
get(int) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
get(int) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
get(int) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
get(int) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
get(int) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
get(int) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
 
get(int) - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
get(int) - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
get(int) - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
get(int) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
get(int) - Method in class com.linkedin.venice.storage.protocol.ChunkId
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
get(int) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
get(int) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
get(int) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
get(int, byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
get(int, byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
get(int, int) - Method in class com.linkedin.venice.utils.collections.BiIntKeyCache
 
get(int, ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
get(long) - Static method in class com.linkedin.venice.unit.matchers.LongEqualOrGreaterThanMatcher
 
get(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
get(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
get(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get(long, TimeUnit) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
get(long, TimeUnit) - Method in class com.linkedin.venice.client.store.AppTimeOutTrackingCompletableFuture
 
get(long, TimeUnit) - Method in class com.linkedin.venice.client.store.streaming.VeniceResponseCompletableFuture
 
get(AbstractStorageEngine, int, byte[], boolean, ReadResponse) - Static method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
 
get(AbstractStorageEngine, int, byte[], ByteBuffer, T, BinaryDecoder, boolean, ReadResponse, int, StoreDeserializerCache<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
get(AbstractStorageEngine, int, VenicePartitioner, PartitionerConfig, byte[], ByteBuffer, T, BinaryDecoder, boolean, ReadResponse, int, StoreDeserializerCache<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
get(AbstractStorageEngine, int, ByteBuffer, boolean, ReadResponse) - Static method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
 
get(AbstractStorageEngine, int, ByteBuffer, boolean, T, BinaryDecoder, ReadResponse, int, StoreDeserializerCache<T>, VeniceCompressor, ChunkedValueManifestContainer) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
get(GetRequestContext, K) - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
get(GetRequestContext, K) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
get(GetRequestContext, K) - Method in class com.linkedin.venice.fastclient.DualReadAvroGenericStoreClient
TODO both super.get(key) and super.get(ctx,key) fetches non map for vsonClient for the first request.
get(GetRequestContext, K) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
get(GetRequestContext, K) - Method in class com.linkedin.venice.fastclient.RetriableAvroGenericStoreClient
TODO: Limit the retry volume: Even though retry for a single request is being scheduled at max twice (once via scheduler (LONG_TAIL_RETRY) and once instant (ERROR_RETRY) if originalRequestFuture fails), there is no way to control the total allowed retry per node.
get(GetRequestContext, K) - Method in class com.linkedin.venice.fastclient.StatsAvroGenericStoreClient
 
get(VeniceClientRequest) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceBlockingStub
 
get(VeniceClientRequest) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceFutureStub
 
get(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.listener.grpc.VeniceReadServiceImpl
 
get(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceImplBase
 
get(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceStub
 
get(MetricsRepository, String) - Method in interface com.linkedin.venice.stats.StatsSupplier
Legacy function, for implementations that do not use total stats in their constructor.
get(MetricsRepository, String, T) - Method in interface com.linkedin.venice.stats.StatsSupplier
This is the function that gets called by AbstractVeniceAggStats, and concrete classes can optionally implement it in order to be provided with the total stats instance.
get(CharSequence) - Method in interface com.linkedin.alpini.base.misc.Headers
 
get(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
get(CharSequence) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
get(CharSequence, String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
get(Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns the value to which the specified key is mapped, or null if this map contains no mapping for the key.
get(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
get(String) - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
 
get(String) - Method in class com.linkedin.venice.client.store.transport.TransportClient
 
get(String) - Method in interface com.linkedin.venice.pubsub.manager.TopicManagerContext.PubSubPropertiesSupplier
 
get(String, Supplier<T>, Consumer<T>) - Method in class com.linkedin.venice.utils.SharedObjectFactory
Get a shared object that has the specified {@param identifier}.
get(String, Map<String, String>) - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
get(String, Map<String, String>) - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
get(String, Map<String, String>) - Method in class com.linkedin.venice.client.store.transport.TransportClient
 
get(String, Map<String, String>) - Method in class com.linkedin.venice.fastclient.transport.GrpcTransportClient
 
get(String, Map<String, String>) - Method in class com.linkedin.venice.fastclient.transport.R2TransportClient
 
get(ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
get(ByteBuffer) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
get(ByteBuffer) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
get(ByteBuffer) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
get(ByteBuffer) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
get(Executor, ClientConfig) - Method in enum com.linkedin.venice.client.store.deserialization.BatchDeserializerType
 
get(K) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
get(K) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
get(K) - Method in class com.linkedin.davinci.client.StatsAvroGenericDaVinciClient
 
get(K) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Get a Value from the partition database
get(K) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
get(K) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
get(K) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
 
get(K) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
get(K) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
get(K) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
get(K) - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Lookup the value by given key, and get(key).get() will return null if it doesn't exist.
get(K) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
 
get(K) - Method in class com.linkedin.venice.client.store.RetriableStoreClient
Adding retry logic on router error as this method returning the completion stage value.
get(K) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
get(K) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
get(K, Version, AsyncCacheLoader<K, V>) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
get(K, Function<K, V>) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
get(K, Function<K, V>) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns the value associated with the key in this cache, obtaining that value from the mappingFunction when a value is not already associated to the key.
get(K, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
get(K, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
get(K, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
 
get(K, V) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
get(K, V) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
get(K, V) - Method in class com.linkedin.davinci.client.StatsAvroGenericDaVinciClient
 
get(K, V) - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Similar to AvroGenericStoreClient.get(Object) except that it allows passing in a {@param reusedValue} instance, to minimize GC.
GET - com.linkedin.venice.authorization.Method
 
GET - com.linkedin.venice.HttpMethod
 
GET_ACL - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_ADMIN_TOPIC_METADATA - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_ALL - com.linkedin.venice.authorization.Method
 
GET_ALL_MIGRATION_PUSH_STRATEGIES - com.linkedin.venice.Command
 
GET_ALL_MIGRATION_PUSH_STRATEGIES - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_ALL_REPLICATION_METADATA_SCHEMAS - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_ALL_VALUE_AND_DERIVED_SCHEMA - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_ALL_VALUE_SCHEMA - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_CLUSTER_STORAGE_PERSONAS - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_DELETABLE_STORE_TOPICS - com.linkedin.venice.Command
 
GET_DELETABLE_STORE_TOPICS - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_EXECUTION - com.linkedin.venice.Command
 
GET_HEARTBEAT_TIMESTAMP_FROM_SYSTEM_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_INUSE_SCHEMA_IDS - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_KAFKA_TOPIC_CONFIGS - com.linkedin.venice.Command
 
GET_KAFKA_TOPIC_CONFIGS - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_KEY_SCHEMA - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_LOADED_STORE_USER_PARTITION_MAPPING - com.linkedin.venice.ingestion.protocol.enums.IngestionAction
 
GET_MIGRATION_PUSH_STRATEGY - com.linkedin.venice.Command
 
GET_ONGOING_INCREMENTAL_PUSH_VERSIONS - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_REGION_PUSH_DETAILS - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_REPUSH_INFO - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_ROUTERS_CLUSTER_CONFIG - com.linkedin.venice.Command
 
GET_ROUTERS_CLUSTER_CONFIG - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_STALE_STORES_IN_CLUSTER - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_STORAGE_PERSONA - com.linkedin.venice.Command
 
GET_STORAGE_PERSONA - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_STORAGE_PERSONA_ASSOCIATED_WITH_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_STORAGE_PERSONA_FOR_STORE - com.linkedin.venice.Command
 
GET_STORE_ACL - com.linkedin.venice.Command
 
GET_STORE_LARGEST_USED_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_STORES_IN_CLUSTER - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_VALUE_OR_DERIVED_SCHEMA_ID - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_VALUE_SCHEMA - com.linkedin.venice.controllerapi.ControllerRoute
 
GET_VALUE_SCHEMA_ID - com.linkedin.venice.controllerapi.ControllerRoute
 
get01Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the 0.1th percentile value.
get01Pct() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
get10Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the 10th percentile value.
get10Pct() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
get1Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the 1th percentile value.
get1Pct() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
get50Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the 50th percentile value.
get50Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the 50th percentile value.
get50Pct() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
get5Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the 5th percentile value.
get5Pct() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
get90Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the 90th percentile value.
get95Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the 95th percentile value.
get99_9Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the 99.9th percentile value.
get99Pct() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the 99th percentile value.
getAbbreviatedNameValuePairs() - Method in class com.linkedin.venice.controllerapi.QueryParams
 
getAccessControlled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'accessControlled' field.
getAccessControlled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getAccessControlled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'accessControlled' field.
getAccessControlled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'accessControlled' field.
getAccessControlledResources() - Method in interface com.linkedin.venice.acl.DynamicAccessController
Get a list of currently being access-controlled resources.
getAccessController() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getAccessibleField(Class<?>, String) - Static method in class com.linkedin.alpini.base.misc.ClassUtil
 
getAccessibleField(Field) - Static method in class com.linkedin.alpini.base.misc.ClassUtil
 
getAccessPermissions() - Method in class com.linkedin.venice.controllerapi.AclResponse
 
getAceEntries() - Method in class com.linkedin.venice.authorization.AclBinding
Returns an unmodifiable list of existing ace entries.
getAclForStore(Admin) - Method in class com.linkedin.venice.controller.server.CreateStore
 
getAclForStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getAclForStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
Fetch the current set of ACL provisioned for a venice store and its associated kafka topic.
getAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getAclHandler(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
getAcquiredChannelCount() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolWithStats
 
getAcquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
getAcquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
getAcquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getAcquireTimeoutMillis() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
getActiveActiveRealTimeSourceFabrics() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'activeActiveReplicationEnabled' field.
getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'activeActiveReplicationEnabled' field.
getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'activeActiveReplicationEnabled' field.
getActiveElementTimestamps() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
getActiveStreams() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getActiveStreams() - Method in interface com.linkedin.alpini.router.impl.Router
 
getActiveStreamsCount() - Method in class io.netty.handler.codec.http2.ActiveStreamsCountHandler
Return the current active streams.
getActiveStreamsCountHandler() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getActiveStreamsCountHandler() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getActiveStreamsLimitReachedCount() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getActiveStreamsLimitReachedCount() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getAdapterSerializer() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAdmin(String, Config) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
 
getAdminAdapterFactory() - Method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
getAdminCommandExecution(long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getAdminCommandExecutionTracker(String) - Method in interface com.linkedin.venice.controller.Admin
Get the tracker used to track the execution of the admin command for the given cluster.
getAdminCommandExecutionTracker(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAdminCommandExecutionTracker(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getAdminConsumerServiceByCluster(String) - Method in class com.linkedin.venice.controller.VeniceControllerService
This method is for testing.
getAdminConsumptionCycleTimeoutMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAdminConsumptionMaxWorkerThreadPoolSize() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAdminConsumptionTimeoutMinutes() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAdminHostname() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAdminHostname() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getAdminOperation() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
 
getAdminPort() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAdminPort() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getAdminProperties() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
 
getAdminSecurePort() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAdminSecurePort() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getAdminTopicMetadata(Admin) - Method in class com.linkedin.venice.controller.server.AdminTopicMetadataRoutes
 
getAdminTopicMetadata(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
 
getAdminTopicMetadata(String, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
 
getAdminTopicMetadata(String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAdminTopicMetadata(String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getAdminTopicMetadata(Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getAdminTopicReplicationFactor() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getAdminTopicSourceRegion() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAge() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getAge() - Method in interface com.linkedin.venice.meta.Version
 
getAge() - Method in class com.linkedin.venice.meta.VersionImpl
 
getAggKafkaConsumerService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getAggregatedMetrics() - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
Gets the value of the 'aggregatedMetrics' field.
getAggregateRealTimeSourceRegion() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getAggregateRealTimeTopicSource(String) - Method in interface com.linkedin.venice.controller.Admin
Return the source Kafka boostrap server url for aggregate real-time topic updates
getAggregateRealTimeTopicSource(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAggregateRealTimeTopicSource(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getAggregates() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'aggregates' field.
getAggregates() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getAggStatistics() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getAggVersionedIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getAggVersionedIngestionStats() - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Get AggVersionedStorageIngestionStats
getAll(CharSequence) - Method in interface com.linkedin.alpini.base.misc.Headers
 
getAll(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getAll(CharSequence) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
getAll(Iterable<K>, Version, Function<Iterable<K>, Map<K, V>>, AsyncCacheLoader<K, V>) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
getAll(Iterable<K>, Function<Iterable<K>, Map<K, V>>) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
getAll(Iterable<K>, Function<Iterable<K>, Map<K, V>>) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns a map of the values associated with the keys, creating or retrieving those values if necessary.
getAll(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getAllDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getAllEnumString() - Static method in enum com.linkedin.venice.migration.MigrationPushStrategy
 
getAllInstances(String, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
This function is mainly used in VeniceVersionFinder#anyOfflinePartitions() when there is no online replica for a specific partition, and it calls this function to get the partition assignment info for error msg.
getAllInstances(String, int) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
Query instances that belong to given kafka topic and partition.
getAllInstancesByExecutionStatus() - Method in class com.linkedin.venice.meta.Partition
 
getAllInstancesByHelixState() - Method in class com.linkedin.venice.meta.Partition
 
getAllInstancesSet() - Method in class com.linkedin.venice.meta.Partition
 
getAllLiveInstances() - Method in class com.linkedin.venice.helix.HelixLiveInstanceMonitor
 
getAllLiveInstances() - Method in interface com.linkedin.venice.meta.LiveInstanceMonitor
 
getAllLocalStorageEngines() - Method in class com.linkedin.davinci.storage.StorageEngineRepository
 
getAllMetricPrefixes(String) - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
getAllMetrics() - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
getAllMigrationPushStrategies(Admin) - Method in class com.linkedin.venice.controller.server.MigrationRoutes
No ACL check; any user is allowed to check migration strategy.
getAllModels() - Method in class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
 
getAllowlist(String) - Method in interface com.linkedin.venice.controller.Admin
 
getAllowlist(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAllowlist(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getAllowList(String) - Method in interface com.linkedin.venice.helix.AllowlistAccessor
Get all helix nodeIds in the allowlist of the given cluster from ZK.
getAllowList(String) - Method in class com.linkedin.venice.helix.ZkAllowlistAccessor
Get all helix nodeIds in the allowlist of the given cluster from ZK.
getAllPartitionNames(String) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
 
getAllPartitionNames(String) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
 
getAllPartitionNames(String) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
 
getAllPartitions() - Method in class com.linkedin.venice.meta.PartitionAssignment
 
getAllPersonas() - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
getAllPersonasFromZk() - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
 
getAllPresent(Iterable<K>) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
getAllPresent(Iterable<K>) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns a map of the values associated with the keys in this cache.
getAllPushNames(String) - Method in class com.linkedin.venice.helix.ParentHelixOfflinePushAccessor
 
getAllPushStrategies() - Method in class com.linkedin.venice.controller.migration.MigrationPushStrategyZKAccessor
The reason to return the push strategy for all the stores: 1.
getAllReplicaStatus(HelixPartitionState, String) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
 
getAllReplicaStatus(String) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
 
getAllReplicationMetadataSchemas(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
 
getAllReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getAllReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getAllSchemasFromResources(AvroProtocolDefinition) - Static method in class com.linkedin.venice.utils.Utils
 
getAllStoreConfigs() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
getAllStoreConfigs() - Method in interface com.linkedin.venice.meta.ReadOnlyStoreConfigRepository
 
getAllStoreConfigs(int, long) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
getAllStorePushStrategyForMigration() - Method in interface com.linkedin.venice.controller.Admin
 
getAllStorePushStrategyForMigration() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Unsupported operation in the child controller.
getAllStorePushStrategyForMigration() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getAllStores() - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getAllStores() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getAllStores() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
So far, this function will return the regular Venice stores + the corresponding meta system store.
getAllStores() - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
getAllStores() - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
getAllStores() - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Get all stores in the current repository
getAllStores(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
No ACL check; any user can try to list stores.
getAllStores(String) - Method in interface com.linkedin.venice.controller.Admin
 
getAllStores(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAllStores(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getAllStoresStatuses(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
No ACL check; any user can try to list store statuses.
getAllStoreStatuses(String) - Method in interface com.linkedin.venice.controller.Admin
Get the statuses of all stores.
getAllStoreStatuses(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getAllStoreStatuses(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getAllTopicRetentions() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Retrieves the retention settings for all Kafka topics.
getAllTopicRetentions() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Retrieves the retention settings for all PubSub topics.
getAllTopicRetentions() - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Get retention time for all topics in the pubsub cluster.
getAllTopicRetentions() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
getAllValueAndDerivedSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
 
getAllValueAndDerivedSchema(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getAllValueSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
Route to handle retrieving all value schema for a given store.
getAllValueSchema(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getAllValueSchemas() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
Returns all value schemas of the store.
getAllValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getAllValueSchemasWithId() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
getAllValueSchemasWithId() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
Returns all value schemas of the store as a map with schema id as the key.
getAllVeniceStoreTopicsRetentions(Map<PubSubTopic, Long>) - Static method in class com.linkedin.venice.controller.kafka.TopicCleanupService
 
getAllVersionNumbers() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
return a deep copy of all version numbers
getAmortizedRefillPerSecond() - Method in class com.linkedin.venice.throttle.TokenBucket
 
getAmplificationFactor() - Method in class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
 
getAmplificationFactor() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getAmplificationFactor() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getAmplificationFactor() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
Gets the value of the 'amplificationFactor' field.
getAmplificationFactor() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getAmplificationFactor() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getAmplificationFactor() - Method in interface com.linkedin.venice.meta.PartitionerConfig
 
getAmplificationFactor() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
getAmplificationFactor() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
Gets the value of the 'amplificationFactor' field.
getAmplificationFactor() - Method in class com.linkedin.venice.metadata.response.VersionProperties
Gets the value of the 'amplificationFactor' field.
getAmplificationFactor() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
Gets the value of the 'amplificationFactor' field.
getAmplificationFactor(ReadOnlyStoreRepository, String) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getAmplificationFactor(ReadOnlyStoreRepository, String, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getAndCacheSchemaDataFromSystemStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getAndExpireOld() - Static method in class com.linkedin.alpini.base.misc.HeaderStringCache
 
getAndIncrementSequenceNumber() - Method in class com.linkedin.venice.kafka.validation.Segment
N.B.
getAndSetStoreConfigFromSystemStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
Get the store cluster config from system store and update the local cache with it.
getAndStartAvroClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getAndStartAvroGenericStoreClient(String) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
 
getAndStartAvroGenericStoreClient(String) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
 
getAndStartAvroGenericStoreClient(String, VeniceStoreClientFactory.ClientConfigUpdater) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
 
getAndStartAvroGenericStoreClient(String, VeniceStoreClientFactory.ClientConfigUpdater) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
create a generic client along with customized client configs.
getAndStartAvroSpecificStoreClient(String, Class<V>) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
 
getAndStartAvroSpecificStoreClient(String, Class<V>) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
 
getAndStartAvroSpecificStoreClient(String, Class<V>, VeniceStoreClientFactory.ClientConfigUpdater) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
 
getAndStartAvroSpecificStoreClient(String, Class<V>, VeniceStoreClientFactory.ClientConfigUpdater) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
 
getAndStartGenericAvroClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getAndStartGenericAvroClient(String, DaVinciConfig) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
getAndStartGenericAvroClient(String, DaVinciConfig) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
 
getAndStartGenericStoreClient(ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
 
getAndStartGenericStoreClient(StoreMetadata, ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
TODO: once we decide to completely remove the helix based implementation, we won't need to pass the param: {@param storeMetadata} in these factory methods.
getAndStartSpecificAvroClient(ClientConfig<V>) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getAndStartSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
getAndStartSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
 
getAndStartSpecificStoreClient(ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
 
getAndStartSpecificStoreClient(StoreMetadata, ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
 
getAndUpdateLeaderCompletedState(KafkaKey, KafkaMessageEnvelope, ControlMessage, PubSubMessageHeaders, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
HeartBeat SOS messages carry the leader completion state in the header.
getAnnotatedDerivedSchemaEntry(DerivedSchemaEntry) - Static method in class com.linkedin.davinci.schema.SchemaUtils
Create a new DerivedSchemaEntry for partial update schema annotation.
getAnnotatedRmdSchemaEntry(RmdSchemaEntry) - Static method in class com.linkedin.davinci.schema.SchemaUtils
 
getAnnotatedValueSchemaEntry(SchemaEntry) - Static method in class com.linkedin.davinci.schema.SchemaUtils
Create a new SchemaEntry for value schema annotation.
getAnnouncingTargetID() - Method in class com.linkedin.venice.d2.D2Server
Get a ID string consists of the attributes that uniquely define the announcing target, which are: 1) doNotStart 2) zkHosts 3) zk announcers (clusterName + nodeUri) -- Note that there should be exactly one announcer according to the current usage in D2ServerFactory.
getAnsiCDate(long) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
getAnsiCDate(Date) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
getAny() - Method in class com.linkedin.venice.meta.StoreDataAudit
 
getApplyTargetVersionFilterForIncPush() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'applyTargetVersionFilterForIncPush' field.
getApplyTargetVersionFilterForIncPush() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'applyTargetVersionFilterForIncPush' field.
getApproximateMemoryUsageByType(Set<Cache>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getArgName() - Method in enum com.linkedin.venice.Arg
 
getAssignedNumberOfPartitions() - Method in class com.linkedin.venice.meta.PartitionAssignment
 
getAssignedResources() - Method in class com.linkedin.venice.helix.ResourceAssignment
 
getAssignment() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
getAssignment() - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the set of PubSub topic-partitions currently assigned to the consumer.
getAssignment() - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
getAttemptsCount() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getAuditMap() - Method in class com.linkedin.venice.controllerapi.ClusterStaleDataAuditResponse
 
getAuthorizerService() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getAutoSchemaRegisterPushJobEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getAvailableChannels() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Returns the channel queue, which holds the available channels with the pool.
getAvailableChannels() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Counts the number of idle channels available within the pool.
getAvailablePermits() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Returns the number of available permits for handshakes.
getAverage() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the average.
getAverage() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the average.
getAverage() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
getAverage() - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
getAverageConcurrency() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getAverageConcurrency() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
Returns the average concurrency over a period of time.
getAverageConcurrency() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getAverageConcurrency15min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getAverageConcurrency15min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getAverageConcurrency1min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getAverageConcurrency1min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getAverageConcurrency5min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getAverageConcurrency5min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getAvg() - Method in class com.linkedin.davinci.stats.WritePathLatencySensor
 
getAvg(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
 
getAvgGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
 
getAvgGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupRoundRobinStrategy
 
getAvgGroupPendingRequest() - Method in interface com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategy
Get the average of the pending requests among all the groups
getAvgGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
getAvgResponseTimeOfLatestPings() - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
getAvroChunkingAdapter() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
getAvroFileHeader(FileSystem, Path, boolean) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
getAvroGenericDeserializer(Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
This function is assuming that both writer and reader are using the same schema.
getAvroGenericDeserializer(Schema, Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
getAvroGenericSerializer(Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
getAvroGenericSerializer(Schema, boolean) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
getAvroKey(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
Return an Avro output key
getAvroKey(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
 
getAvroKey(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
 
getAvroKey(BytesWritable, BytesWritable) - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
 
getAvroSpecificDeserializer(Class<V>) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
This function is assuming that both writer and reader are using the same schema defined in {@param c}.
getAvroSpecificDeserializer(Schema, Class<V>) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
getAvroSpecificDeserializerInternal(Schema, Class<V>, Function<SerializerDeserializerFactory.SchemaPairAndClassContainer, AvroSpecificDeserializer<? extends SpecificRecord>>) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
getAvroValue(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
return an Avro output value
getAvroValue(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
 
getAvroValue(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
 
getAvroValue(BytesWritable, BytesWritable) - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
 
getBackend() - Static method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
getBackendConfig() - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
getBackupStrategy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'backupStrategy' field.
getBackupStrategy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getBackupStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getBackupStrategy() - Method in interface com.linkedin.venice.meta.Store
 
getBackupStrategy() - Method in class com.linkedin.venice.meta.StoreInfo
 
getBackupStrategy() - Method in class com.linkedin.venice.meta.SystemStore
 
getBackupStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'backupStrategy' field.
getBackupStrategy() - Method in class com.linkedin.venice.meta.ZKStore
 
getBackupStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'backupStrategy' field.
getBackupVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getBackupVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getBackupVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getBackupVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getBackupVersionDefaultRetentionMs() - Method in interface com.linkedin.venice.controller.Admin
Returns default backup version retention time.
getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getBackupVersionNumber(List<Version>, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Get backup version number, the largest online version number that is less than the current version number
getBackupVersionRetentionMs() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'backupVersionRetentionMs' field.
getBackupVersionRetentionMs() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getBackupVersionRetentionMs() - Method in interface com.linkedin.venice.meta.Store
 
getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.StoreInfo
 
getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.SystemStore
 
getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.ZKStore
 
getBackupVersionRetentionMs() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'backupVersionRetentionMs' field.
getBackupVersions(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getBackupVersionsForMultiColos(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getBackupVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getBackupVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getBadMetaSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
 
getBadPushStatusSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
 
getBatchConflictResolutionPolicy() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'batchConflictResolutionPolicy' field.
getBatchFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getBatchFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getBatchFollowerOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getBatchGetDeserializer(Executor) - Method in class com.linkedin.venice.client.store.ClientConfig
 
getBatchGetLimit() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'batchGetLimit' field.
getBatchGetLimit() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getBatchGetLimit() - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
getBatchGetLimit() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getBatchGetLimit() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getBatchGetLimit() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getBatchGetLimit() - Method in interface com.linkedin.venice.meta.Store
 
getBatchGetLimit() - Method in class com.linkedin.venice.meta.StoreInfo
 
getBatchGetLimit() - Method in class com.linkedin.venice.meta.SystemStore
 
getBatchGetLimit() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'batchGetLimit' field.
getBatchGetLimit() - Method in class com.linkedin.venice.meta.ZKStore
 
getBatchGetLimit() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'batchGetLimit' field.
getBatchGetLimit() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'batchGetLimit' field.
getBatchGetLimit(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getBatchGetLimit(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getBatchGetLimit(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
getBatchGetLimit(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
Only return zk shared system store related info, otherwise VeniceException will be thrown.
getBatchGetLimit(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Get batch-get limit for the specified store
getBatchGetMethod() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
 
getBatchGetRouterCacheEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'batchGetRouterCacheEnabled' field.
getBatchGetRouterCacheEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'batchGetRouterCacheEnabled' field.
getBatchJobHeartbeatEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getBatchJobHeartbeatEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getBatchJobHeartbeatInitialBufferTime() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getBatchJobHeartbeatInitialBufferTime() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getBatchJobHeartbeatStoreCluster() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getBatchJobHeartbeatStoreCluster() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getBatchJobHeartbeatTimeout() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getBatchJobHeartbeatTimeout() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getBatchJobHeartbeatValue(BatchJobHeartbeatKey) - Method in interface com.linkedin.venice.controller.Admin
 
getBatchJobHeartbeatValue(BatchJobHeartbeatKey) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getBatchJobHeartbeatValue(BatchJobHeartbeatKey) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getBatchLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getBatchLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getBatchLeaderOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getBatchReplicationLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getBatchReplicationLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getBatchReplicationLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getBenignLeaderOffsetRewindCount() - Method in class com.linkedin.davinci.stats.DIVStats
 
getBenignLeaderProducerFailure() - Method in class com.linkedin.davinci.stats.DIVStats
 
getBlobTransferEnabled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getBlobTransferEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'blobTransferEnabled' field.
getBlobTransferEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getBlobTransferEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'blobTransferEnabled' field.
getBlobTransferEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'blobTransferEnabled' field.
getBlobTransferEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'blobTransferEnabled' field.
getBlockBaseFormatVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getBlockedInstanceCount() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
 
getBlockingQueueType() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getBlockingReason() - Method in class com.linkedin.venice.controller.NodeRemovableResult
 
getBlockingResource() - Method in class com.linkedin.venice.controller.NodeRemovableResult
 
getBody() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
 
getBody() - Method in class com.linkedin.venice.listener.response.BinaryResponse
 
getBody() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
getBody() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getBody() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
getBodyParams() - Method in enum com.linkedin.venice.controllerapi.routes.V1Post
 
getBodyParams() - Method in enum com.linkedin.venice.controllerapi.routes.V1Put
 
getBoolean(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getBoolean(String, boolean) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getBooleanWithAlternative(String, String, boolean) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getBootstrapFileSystemPath() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getBootstrappingChangelogConsumer(String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
 
getBootstrappingChangelogConsumer(String, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
 
getBootstrappingChangelogConsumer(String, String, Class) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
Creates a BootstrappingVeniceChangelogConsumer with consumer id.
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'bootstrapToOnlineTimeoutInHours' field.
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getBootstrapToOnlineTimeoutInHours() - Method in interface com.linkedin.venice.meta.Store
 
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.StoreInfo
 
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.SystemStore
 
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'bootstrapToOnlineTimeoutInHours' field.
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.ZKStore
 
getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'bootstrapToOnlineTimeoutInHours' field.
getBrokerAddress() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
 
getBrokerAddress() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
 
getBrokerAddress() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
getBrokerAddress() - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
 
getBrokerAddress() - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
 
getBrokerAddress() - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
 
getBrokerAddress() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getBucketForStore(String) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
getBufferReplayEnabledForHybrid() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'bufferReplayEnabledForHybrid' field.
getBufferReplayEnabledForHybrid() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'bufferReplayEnabledForHybrid' field.
getBufferReplayPolicy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Gets the value of the 'bufferReplayPolicy' field.
getBufferReplayPolicy() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
getBufferReplayPolicy() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
getBufferReplayPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Gets the value of the 'bufferReplayPolicy' field.
getByIndex(int) - Method in class com.linkedin.davinci.utils.IndexedHashMap
O(1)
getByIndex(int) - Method in interface com.linkedin.davinci.utils.IndexedMap
 
getByIndex(int) - Method in interface com.linkedin.venice.utils.IndexedMap
 
getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Populate provided callback with key-value pairs from the partition database where the keys have provided prefix.
getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getByKeyPrefix(int, byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getByPartialKey(AbstractStorageEngine, int, PartitionerConfig, byte[], T, BinaryDecoder, RecordDeserializer<GenericRecord>, boolean, ReadResponse, int, StoreDeserializerCache<T>, VeniceCompressor, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
getByteRate() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
getBytes() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
 
getBytesCompressed() - Method in class com.linkedin.alpini.io.PigzOutputStream
Returns how many bytes has been written to this OutputStream.
getBytesConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getBytesRemaining() - Method in class com.linkedin.alpini.io.ZeroInputStream
 
getBytesWritten() - Method in class com.linkedin.alpini.io.MeteredOutputStream
 
getBytesWritten() - Method in class com.linkedin.alpini.io.NullOutputStream
 
getBytesWritten() - Method in class com.linkedin.alpini.io.PigzOutputStream
Returns how many bytes has been written to the underlying OutputStream.
getCache() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
getCacheConfig() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
getCachedRMDSizeInBytes() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getCachedRMDSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
getCachedStoreSizeInBytes() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getCachedStoreSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
getCachedTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Still heavy, but can be called repeatedly to amortize that cost.
getCacheInvalidatingStoreChangeListener() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
getCallback() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
getCallback() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
getCallback() - Method in class com.linkedin.venice.writer.CompletableFutureCallback
 
getCallCountTotal() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getCallCountTotal() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getCallStartCountTotal() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getCallStartCountTotal() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getCallStats() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getCallStats() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getCallStats() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getCallTimeStats() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
Returns the call time stats in nanoseconds.
getCallTimeStats() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getCanonicalPath(String) - Static method in class com.linkedin.venice.utils.Utils
Get the full Path of the file.
getCanonicalSchemaStr() - Method in class com.linkedin.venice.schema.SchemaEntry
 
getCappedPrefixExtractorLength() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getCause() - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Returns the cause of the failed I/O operation if the I/O operation has failed.
getCause() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
getCause() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Returns the cause of the failed I/O operation if the I/O operation has failed.
getCause() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Returns the cause of the failed I/O operation if the I/O operation has failed.
getCause(Throwable, Class<?>...) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Return the cause of the given Throwable if the cause is one of the classes provided; otherwise return the Throwable itself.
getCertificate(Request) - Static method in class com.linkedin.venice.controller.server.AbstractRoute
Helper function to get certificate out of Spark request
getCertification(Credentials, Text) - Method in class com.linkedin.venice.hadoop.ssl.TempFileSSLConfigurator
 
getChangeFuture() - Method in interface com.linkedin.alpini.router.api.HostFinder
Returns an async future which is completed when a change in the routing table occurs.
getChangelogClientConfig() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
getChangelogConsumer(String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
Default method to create a VeniceChangelogConsumer given a storeName.
getChangelogConsumer(String, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
Creates a VeniceChangelogConsumer with consumer id.
getChannel(String) - Method in class com.linkedin.venice.fastclient.transport.GrpcTransportClient
 
getChannelPoolHandler(Channel) - Static method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
getChannelReusePoolSize() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getChannelReusePoolSize() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
Returns the current reuse channel pool size.
getCharSequenceFromGuid(GUID) - Static method in class com.linkedin.venice.guid.GuidUtils
 
getCharSequenceMapFromStringMap(Map<String, String>) - Static method in class com.linkedin.venice.utils.CollectionUtils
 
getCheckedOut15min() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getCheckedOut1min() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the number of pool objects checked out at the time of the call to getStats().
getCheckedOut5min() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getCheckedOutTime50Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getCheckedOutTime95Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getCheckedOutTime99Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getCheckedOutTimeAvg() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getCheckpointUpstreamVersionTopicOffset() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
Get the checkSum of the buffer till now.
getChecksumState() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'checksumState' field.
getCheckSumState() - Method in class com.linkedin.venice.kafka.validation.Segment
`synchronized` keyword will guarantee the caller will always get the checksum after processing the full record in function: Segment.addToCheckSum(KafkaKey, KafkaMessageEnvelope).
getChecksumType() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
Gets the value of the 'checksumType' field.
getChecksumType() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'checksumType' field.
getCheckSumType() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getChecksumValue() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
Gets the value of the 'checksumValue' field.
getChildChannelPool() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
getChildControllerAdminTopicConsumptionEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
getChildControllerD2ServiceName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getChildControllerD2ServiceName(String) - Method in interface com.linkedin.venice.controller.Admin
Get child datacenter controller d2 service name
getChildControllerD2ServiceName(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getChildControllerD2ServiceName(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getChildControllerD2ZkHost(String) - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getChildControllers(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
 
getChildControllerUrl(String) - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getChildDataCenterAllowlist() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getChildDataCenterControllerD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getChildDataCenterControllerD2Map() - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
 
getChildDataCenterControllerD2Map(String) - Method in interface com.linkedin.venice.controller.Admin
Get child datacenter to child controller d2 zk host mapping
getChildDataCenterControllerD2Map(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getChildDataCenterControllerD2Map(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getChildDataCenterControllerUrlMap() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
Map where keys are logical, human-readable names for child clusters (suitable for printing in logs or other output) values are a list of cluster URLs that can be used to reach that cluster with the controller client.
getChildDataCenterControllerUrlMap() - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
 
getChildDataCenterControllerUrlMap(String) - Method in interface com.linkedin.venice.controller.Admin
Get child datacenter to child controller url mapping.
getChildDataCenterControllerUrlMap(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getChildDataCenterControllerUrlMap(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getChildDataCenterKafkaUrlMap() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getChildDataCenterKafkaUrlMap() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getChildDatacenters() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getChildNames(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
getChildPredicates() - Method in class com.linkedin.venice.client.store.predicate.AndPredicate
 
getChildren(ZkBaseDataAccessor<T>, String, int, long) - Static method in class com.linkedin.venice.utils.HelixUtils
 
getChildValues(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
N.B.: The behavior of this function is different from that of HelixDataAccessor, which would swallow exceptions and return an empty collection.
getChildValuesMap(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
N.B.: The behavior of this function is different from that of HelixDataAccessor, which would swallow exceptions and return an empty collection.
getChunked() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Gets the value of the 'chunked' field.
getChunked() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'chunked' field.
getChunkedKeySuffix() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Gets the value of the 'chunkedKeySuffix' field.
getChunkedKeySuffixBytes() - Method in class com.linkedin.venice.chunking.RawKeyBytesAndChunkedKeySuffix
 
getChunkedResponse() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getChunkedValueManifest() - Method in class com.linkedin.venice.writer.ChunkedPayloadAndManifest
 
getChunkId() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
Gets the value of the 'chunkId' field.
getChunkIndex() - Method in class com.linkedin.venice.storage.protocol.ChunkId
Gets the value of the 'chunkIndex' field.
getChunkingEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'chunkingEnabled' field.
getChunkingEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getChunkingEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'chunkingEnabled' field.
getChunkingEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'chunkingEnabled' field.
getChunkingEnabled() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'chunkingEnabled' field.
getChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'chunkingEnabled' field.
getChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'chunkingEnabled' field.
getCiphers(Provider, SslProvider) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
getClassName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
 
getClassName() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
 
getClassName() - Method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
 
getClassName() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
getClasspath() - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
 
getClassSchema() - Static method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
getClassSchema() - Static method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
getClassSchema() - Static method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
getClassSchema() - Static method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
getClassSchema() - Static method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
getClassSchema() - Static method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.Count
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.DotProduct
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
getClassSchema() - Static method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
getClassSchema() - Static method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
getClassSchema() - Static method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
getClassSchema() - Static method in enum com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
 
getClassSchema() - Static method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.ControlMessage
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.Delete
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.EndOfPush
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.GUID
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.Put
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfPush
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.Update
 
getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.VersionSwap
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
getClassSchema() - Static method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
getClassSchema() - Static method in class com.linkedin.venice.metadata.response.VersionProperties
 
getClassSchema() - Static method in class com.linkedin.venice.participant.protocol.KillPushJob
 
getClassSchema() - Static method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
getClassSchema() - Static method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
getClassSchema() - Static method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
getClassSchema() - Static method in class com.linkedin.venice.pushstatus.PushStatusKey
 
getClassSchema() - Static method in class com.linkedin.venice.pushstatus.PushStatusValue
 
getClassSchema() - Static method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
getClassSchema() - Static method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
getClassSchema() - Static method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
getClassSchema() - Static method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
getClassSchema() - Static method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
getClassSchema() - Static method in class com.linkedin.venice.status.protocol.PushJobDetails
 
getClassSchema() - Static method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
getClassSchema() - Static method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
getClassSchema() - Static method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
getClassSchema() - Static method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
getClassSchema() - Static method in class com.linkedin.venice.storage.protocol.ChunkId
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
getClient() - Method in class com.linkedin.venice.httpclient.HttpClientUtils.ClosableHttpAsyncClientWithConnManager
 
getClient(String, DaVinciConfig, Class, CachingDaVinciClientFactory.DaVinciClientConstructor, Class, boolean) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
getClientAccessMethod() - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
getClientConfig() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getClientConfig() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
getClientConfig() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getClientConfig() - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
getClientConfigForConsumer() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getClientDecompressionEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'clientDecompressionEnabled' field.
getClientDecompressionEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getClientDecompressionEnabled() - Method in interface com.linkedin.venice.meta.Store
 
getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'clientDecompressionEnabled' field.
getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
getClientDecompressionEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'clientDecompressionEnabled' field.
getClientResolutionRetryAttempts() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getClientResolutionRetryBackoffMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getClientRoutingStrategyType() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getClientSslHandshakeQueueCapacity() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getClientSslHandshakeThreads() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getClientStats(MetricsRepository, String, RequestType, ClientConfig) - Static method in class com.linkedin.venice.client.stats.BasicClientStats
 
getClientStats(MetricsRepository, String, RequestType, ClientConfig) - Static method in class com.linkedin.venice.client.stats.ClientStats
 
getClientStats(MetricsRepository, String, String, RequestType) - Static method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
getClosableProducer(String, Config, MetricsRegistry) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Convenience method to hide the ugliness of casting in just one place.
getCluster() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
getCluster() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
 
getCluster() - Method in class com.linkedin.venice.datarecovery.Command.Result
 
getCluster() - Method in class com.linkedin.venice.meta.StoreConfig
 
getCluster() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Gets the value of the 'cluster' field.
getClusterDiscoveryD2Service() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getClusterDiscoveryD2ServiceName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getClusterInfoProvider() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
getClusterLockManager() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getClusterMaintenanceSignal(String, SafeHelixManager) - Static method in class com.linkedin.venice.utils.HelixUtils
If a cluster is in maintenance mode it returns all the signals associated with it regarding the reason and other details for creating the maintenance mode.
getClusterManagmentTool() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getClusterName() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Gets the value of the 'clusterName' field.
getClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
 
getClusterName() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
getClusterName() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceNoClusterException
 
getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
 
getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
 
getClusterName() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getClusterName() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getClusterName() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'clusterName' field.
getClusterNameFromTopicName(String) - Static method in class com.linkedin.venice.controller.kafka.AdminTopicUtils
 
getClusterProperties() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getClusters() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getClustersLeaderOf() - Method in interface com.linkedin.venice.controller.Admin
Get a list of clusters this controller is a leader of.
getClustersLeaderOf() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getClustersLeaderOf() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getClusterStaleStores(String) - Method in interface com.linkedin.venice.controller.Admin
 
getClusterStaleStores(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getClusterStaleStores(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
This function will iterate over all of Helix Parent Admin's child controllers, in order to ask about stale stores.
getClusterStaleStores(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getClusterStats() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getClusterStoragePersonas() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getClusterStoragePersonas(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
 
getClusterStoragePersonas(String) - Method in interface com.linkedin.venice.controller.Admin
 
getClusterStoragePersonas(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getClusterStoragePersonas(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getClusterStores(String) - Method in interface com.linkedin.venice.controller.Admin
Return all stores in a cluster.
getClusterStores(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getClusterStores(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getClusterStores(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getClusterSystemStoreHealthCheckStats(String) - Method in class com.linkedin.venice.controller.systemstore.SystemStoreRepairTask
 
getClusterToD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getClusterToD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getClusterToD2Map() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getClusterToD2String(Map<String, String>) - Static method in class com.linkedin.venice.utils.TestUtils
 
getClusterToServerD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getClusterToServerD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getClusterToServerD2Map() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getCmdParams() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskParams
 
getCmdResult() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
 
getCollectedNumberOfSamples() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
 
getColoStatus() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'coloStatus' field.
getColoToCurrentVersions() - Method in class com.linkedin.venice.meta.StoreInfo
 
getColumnFamilyHandleList() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getCombinedProperties() - Method in class com.linkedin.davinci.config.VeniceConfigLoader
 
getCommand() - Method in class com.linkedin.alpini.base.queuing.QOSBasedRequestRunnable
 
getCommand() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
 
getCommand() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getCommand(String, CommandLine) - Static method in enum com.linkedin.venice.Command
 
getCommandLine(String[]) - Static method in class com.linkedin.venice.AdminTool
 
getCommandType() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
Gets the value of the 'commandType' field.
getCommonComputeSpec() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
Generate compute spec for projections, dot-product and cosine-similarity.
getCommonConfig() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getCommonResultFields() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
Generate compute result schema fields for projections, dot-product and cosine-similarity.
getCompactSize() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
getCompiledProtocol() - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
getCompletedStatusReplicas(String, int) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
 
getCompletionReported() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'completionReported' field.
getComponentType() - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
Gets the value of the 'componentType' field.
getCompressionDictionary() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Gets the value of the 'compressionDictionary' field.
getCompressionDictionary() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'compressionDictionary' field.
getCompressionStrategy() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getCompressionStrategy() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getCompressionStrategy() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getCompressionStrategy() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
 
getCompressionStrategy() - Method in class com.linkedin.venice.compression.VeniceCompressor
 
getCompressionStrategy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getCompressionStrategy() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getCompressionStrategy() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getCompressionStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getCompressionStrategy() - Method in interface com.linkedin.venice.meta.Store
 
getCompressionStrategy() - Method in class com.linkedin.venice.meta.StoreInfo
 
getCompressionStrategy() - Method in class com.linkedin.venice.meta.SystemStore
 
getCompressionStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy() - Method in interface com.linkedin.venice.meta.Version
 
getCompressionStrategy() - Method in class com.linkedin.venice.meta.VersionImpl
 
getCompressionStrategy() - Method in class com.linkedin.venice.meta.ZKStore
 
getCompressionStrategy() - Method in class com.linkedin.venice.metadata.response.VersionProperties
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 compressionStrategy = 3;
getCompressionStrategy() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
uint32 compressionStrategy = 3;
getCompressionStrategy() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
uint32 compressionStrategy = 3;
getCompressionStrategy() - Method in class com.linkedin.venice.router.api.ContentDecompressResult
 
getCompressionStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'compressionStrategy' field.
getCompressionStrategy(String) - Static method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
 
getCompressionStrategyTypesArrayLength() - Static method in enum com.linkedin.venice.compression.CompressionStrategy
 
getCompressor() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getCompressor(CompressionStrategy) - Method in class com.linkedin.venice.compression.CompressorFactory
 
getCompressor(CompressionStrategy, int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getCompressor(CompressionStrategy, int) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getCompressor(CompressionStrategy, int) - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getCompressor(CompressionStrategy, int, CompressorFactory, Map<Integer, ByteBuffer>) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
getCompressor(CompressionStrategy, String) - Method in class com.linkedin.davinci.compression.StorageEngineBackedCompressorFactory
 
getCompressor(CompressorFactory, CompressionStrategy, String, String, VeniceProperties) - Static method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputUtils
 
getCompressorFactory() - Method in class com.linkedin.davinci.DaVinciBackend
 
getCompressorFactory() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getComputedAggregates() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
Gets the value of the 'computedAggregates' field.
getComputeQueueCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getComputeRequest() - Method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
 
getComputeRequestLengthInBytes() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
getComputeRequestOperations() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
Generate compute operations for projections, dot-product and cosine-similarity.
getComputeRequestOperations() - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
 
getComputeRequestPath() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getComputeTardyLatencyThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getConcurrency() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getConcurrency() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getConfig() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getConfig() - Method in class com.linkedin.venice.controllerapi.RoutersClusterConfigResponse
 
getConfig() - Method in class com.linkedin.venice.router.RouterServer
 
getConfig(VenicePulsarSinkConfig, String) - Static method in class com.linkedin.venice.pulsar.sink.VenicePulsarSink
 
getConfigAccessor() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getConfigLoader() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getConfigLoader() - Method in class com.linkedin.venice.server.VeniceServer
 
getConfigMap() - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
Gets the value of the 'configMap' field.
getConfigName() - Method in class com.linkedin.venice.utils.Utils.ConfigEntity
 
getConfigs() - Method in class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
 
getConfigs() - Method in interface com.linkedin.venice.meta.ReadOnlyLiveClusterConfigRepository
Get live cluster configs
getConfigs() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Gets the value of the 'configs' field.
getConfigService() - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
getConfiguredMaxRatePerSecond() - Method in class com.linkedin.venice.throttle.EventThrottler
 
getConnectedChannels() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
getConnectedChannels() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
getConnectedChannels() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getConnectedChannels() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getConnectedCount() - Method in class com.linkedin.alpini.netty4.handlers.ConnectionControlHandler
 
getConnectedCount() - Method in class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
Return the current number of connections.
getConnectedCount() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getConnectedCount() - Method in interface com.linkedin.alpini.router.impl.Router
 
getConnectionLimit() - Method in class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
Return the current connection limit.
getConnectionLimit() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getConnectionLimit() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getConnectionTimeout() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getConnManager() - Method in class com.linkedin.venice.httpclient.HttpClientUtils.ClosableHttpAsyncClientWithConnManager
 
getConsumedKafkaClusterId() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getConsumedOffset() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getConsumedRecordEndToEndProcessingLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getConsumedRecordEndToEndProcessingLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getConsumer(String, Config, MetricsRegistry) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
 
getConsumerAdapterFactory() - Method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
getConsumerAssignedToVersionTopicPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
getConsumerAssignedToVersionTopicPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
getConsumerAssignedToVersionTopicPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
getConsumeRemotely() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'consumeRemotely' field.
getConsumerIdx() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
getConsumerName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getConsumerPoolSizePerKafkaCluster() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getConsumerProperties() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getConsumerProperties(JobConf) - Static method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputUtils
 
getConsumptionSnapshots(String, ComplementSet<Integer>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getConsumptionSnapshots(String, ComplementSet<Integer>) - Method in interface com.linkedin.davinci.storage.IngestionMetadataRetriever
 
getConsumptionSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getConsumptionSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getConsumptionStartTimeInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getContent() - Method in class com.linkedin.venice.router.api.ContentDecompressResult
 
getContentInByteBuf() - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
Returns the response as ByteBuf.
getContext(String, ClassLoader, Object, boolean) - Method in class com.linkedin.alpini.log.FastLogContextFactory
 
getContext(String, ClassLoader, Object, boolean, URI, String) - Method in class com.linkedin.alpini.log.FastLogContextFactory
 
getContinueExistingPeriodicTasksAfterShutdownPolicy() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Gets the policy on whether to continue executing existing periodic tasks even when this executor has been shutdown.
getControllerClient(String, String, D2Client) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
 
getControllerClient(String, String, String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
 
getControllerClient(String, String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.ControllerClientFactory
 
getControllerClientMap(String) - Method in class com.linkedin.venice.controller.systemstore.SystemStoreRepairTask
 
getControllerClientMap(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getControllerClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getControllerClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getControllerClusterReplica() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getControllerClusterReplica() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getControllerClusterZkAddress() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getControllerClusterZkAddress() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getControllerConfig(String) - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getControllerD2ServiceName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getControllerDiscoveryUrl(Config) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
 
getControllerDiscoveryUrls() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getControllerHAASSuperClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getControllerHAASSuperClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getControllerName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getControllerName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getControllerRequestRetryCount() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getControlMessageType() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
Gets the value of the 'controlMessageType' field.
getControlMessageUnion() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
Gets the value of the 'controlMessageUnion' field.
getCopyIfNotUsableInCallback() - Method in class com.linkedin.venice.client.store.transport.HttpsTransportClient
The same CloseableHttpAsyncClient could not be used to send out another request in its own callback function.
getCopyIfNotUsableInCallback() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
The same CloseableHttpAsyncClient could not be used to send out another request in its own callback function.
getCopyIfNotUsableInCallback() - Method in class com.linkedin.venice.client.store.transport.TransportClient
If the internal client could not be used by its callback function, implementation of this function should return a new copy.
getCorruptedMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
getCosineSimilarityCount() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getCosSimilarityParam() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
Gets the value of the 'cosSimilarityParam' field.
getCount() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the count.
getCount() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the count.
getCount() - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
getCounterName() - Method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper.GroupAndCounterNames
 
getCountOperatorCount() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getCreateCallStats() - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
getCreatedTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getCreatedTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getCreatedTime() - Method in interface com.linkedin.venice.meta.Store
 
getCreatedTime() - Method in class com.linkedin.venice.meta.SystemStore
 
getCreatedTime() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'createdTime' field.
getCreatedTime() - Method in interface com.linkedin.venice.meta.Version
 
getCreatedTime() - Method in class com.linkedin.venice.meta.VersionImpl
 
getCreatedTime() - Method in class com.linkedin.venice.meta.ZKStore
 
getCreatedTime() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'createdTime' field.
getCreatedTime() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'createdTime' field.
getCreateTime50Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 50 percentage time to create an object.
getCreateTime95Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 95 percentage time to create an object.
getCreateTime99Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 99 percentage time to create an object.
getCreateTimeAvg() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the average time to create an object.
getCreateTimestampInMs() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getCreationTime() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'creationTime' field.
getCredentials() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
 
getCurrentCallCountTotal() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getCurrentCallCountTotal() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getCurrentCallCountTotal() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getCurrentConcurrency() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getCurrentConcurrency() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getCurrentConcurrency() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getCurrentContext() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
getCurrentDate() - Method in class com.linkedin.venice.utils.MockCircularTime
 
getCurrentDate() - Method in class com.linkedin.venice.utils.SystemTime
 
getCurrentErrorCountTotal() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getCurrentErrorCountTotal() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getCurrentErrorCountTotal() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getCurrentKey() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
 
getCurrentKey() - Method in interface com.linkedin.venice.hadoop.input.recordreader.VeniceRecordIterator
Return the current key.
getCurrentKey() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
 
getCurrentLineNumber() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
getCurrentLineOffset() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
getCurrentOffset() - Method in class com.linkedin.venice.meta.UncompletedReplica
 
getCurrentPendingRequestCount() - Method in class com.linkedin.venice.router.throttle.PendingRequestThrottler
 
getCurrentProgress() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
getCurrentProtocolVersion() - Method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
 
getCurrentProtocolVersionSchema() - Method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
 
getCurrentSecond() - Static method in class com.linkedin.alpini.base.misc.RetryCounter
Return current second starting based on System.nanoTime.
getCurrentStartCountTotal() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getCurrentStartCountTotal() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getCurrentStartCountTotal() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getCurrentStats() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
 
getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.RouterBasedPushMonitor
 
getCurrentStoreVersion() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getCurrentStoreVersion() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getCurrentStoreVersion() - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getCurrentStreamChannelsReused() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getCurrentStreamChannelsReused() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
GetCurrentThread() - Method in interface com.linkedin.alpini.jna.ThreadUtils.WindowsCLib
 
getCurrentTimeNanos() - Method in class com.linkedin.alpini.netty4.handlers.Http2PingSendHandler
 
getCurrentUser() - Static method in class com.linkedin.venice.utils.Utils
 
getCurrentValue() - Method in class com.linkedin.davinci.consumer.ChangeEvent
 
getCurrentValue() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Gets the value of the 'currentValue' field.
getCurrentValue() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
 
getCurrentValue() - Method in interface com.linkedin.venice.hadoop.input.recordreader.VeniceRecordIterator
Return the current value.
getCurrentValue() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
 
getCurrentVersion() - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
 
getCurrentVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
getCurrentVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
getCurrentVersion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
Gets the value of the 'currentVersion' field.
getCurrentVersion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'currentVersion' field.
getCurrentVersion() - Method in class com.linkedin.venice.controllerapi.CurrentVersionResponse
 
getCurrentVersion() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getCurrentVersion() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getCurrentVersion() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getCurrentVersion() - Method in interface com.linkedin.venice.meta.Store
 
getCurrentVersion() - Method in class com.linkedin.venice.meta.StoreInfo
The version of the store which is currently being served
getCurrentVersion() - Method in class com.linkedin.venice.meta.SystemStore
 
getCurrentVersion() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
Gets the value of the 'currentVersion' field.
getCurrentVersion() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'currentVersion' field.
getCurrentVersion() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
getCurrentVersion() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
getCurrentVersion() - Method in class com.linkedin.venice.meta.ZKStore
 
getCurrentVersion() - Method in class com.linkedin.venice.metadata.response.VersionProperties
Gets the value of the 'currentVersion' field.
getCurrentVersion() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'currentVersion' field.
getCurrentVersion() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Gets the value of the 'currentVersion' field.
getCurrentVersion(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
return Store.NON_EXISTING_VERSION if current version doesn't exist.
getCurrentVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getCurrentVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getCurrentVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getCurrentVersionResponse(String) - Method in interface com.linkedin.davinci.storage.ReadMetadataRetriever
 
getCurrentVersionResponse(String) - Method in class com.linkedin.venice.listener.ServerReadMetadataRepository
 
getCurrentVersionsForMultiColos(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getCurrentVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getCurrentVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Query the current version for the given store.
getCurrentVersionStates() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
Gets the value of the 'currentVersionStates' field.
getCurrentWorkingDirectory() - Static method in class com.linkedin.venice.utils.Utils
 
getCustomizedViewRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getD2BasePath() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getD2Client() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getD2Client() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getD2Client() - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
getD2Client() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getD2Client() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getD2Client(String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.d2.D2ClientFactory
 
getD2ControllerClient() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getD2Service() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
getD2ServiceName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getD2ServiceName() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getD2ServiceName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getD2ServiceName() - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
 
getD2ServiceName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
 
getD2ServiceName(String) - Static method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
 
getD2ZkTimeout() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getData() - Method in class com.linkedin.davinci.store.record.ValueRecord
 
getData() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
bytes data = 2;
getData() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
bytes data = 2;
getData() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
bytes data = 2;
getDataAge() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getDatabaseInfo() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'databaseInfo' field.
getDatabaseInfo() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getDatabaseLookupLatency() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getDatabaseLookupQueueCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDatabaseOpenOperationThrottle() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getDataBasePath() - Method in class com.linkedin.davinci.config.VeniceServerConfig
Get base path of Venice storage data.
getDatabaseSyncBytesInterval() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
Gets the databaseSyncBytesInterval.
getDatabaseSyncBytesIntervalForDeferredWriteMode() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDatabaseSyncBytesIntervalForTransactionalMode() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDatacenterCount(String) - Method in interface com.linkedin.venice.controller.Admin
number of datacenters, 1 if in single cluster mode.
getDatacenterCount(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getDataInBytes() - Method in class com.linkedin.davinci.store.record.ValueRecord
 
getDataRecordDeserializer(int) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getDataRecordDeserializer(int) - Method in class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
 
getDataRecordDeserializer(int) - Method in class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
 
getDataRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getDataRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingAvroSpecificStoreClient
 
getDataRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingVsonStoreClient
Deprecated.
 
getDataRecoveryConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'dataRecoveryConfig' field.
getDataRecoverySourceFabric() - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
 
getDataRecoverySourceFabric() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
getDataRecoverySourceFabric() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Gets the value of the 'dataRecoverySourceFabric' field.
getDataRecoverySourceVersionNumber() - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
 
getDataRecoverySourceVersionNumber() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
getDataRecoverySourceVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Gets the value of the 'dataRecoverySourceVersionNumber' field.
getDataRecoveryVersionConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getDataRecoveryVersionConfig() - Method in interface com.linkedin.venice.meta.Version
 
getDataRecoveryVersionConfig() - Method in class com.linkedin.venice.meta.VersionImpl
 
getDataReplicationPolicy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Gets the value of the 'dataReplicationPolicy' field.
getDataReplicationPolicy() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
getDataReplicationPolicy() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
getDataReplicationPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Gets the value of the 'dataReplicationPolicy' field.
getDataReplicationPolicyMap() - Static method in enum com.linkedin.venice.meta.DataReplicationPolicy
 
getDataSchema() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
 
getDataSize() - Method in class com.linkedin.davinci.store.record.ValueRecord
 
getDataWriterTaskTracker() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
getDataWriterTaskTracker() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
getDateTime() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
 
getDaVinciClientForMetaStore() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getDaVinciCurrentVersion() - Method in class com.linkedin.davinci.StoreBackend
 
getDaVinciPartitionLevelPushStatusAndDetails(PushStatusStoreReader, String, int, Optional<String>, int, double, boolean) - Static method in class com.linkedin.venice.pushmonitor.PushMonitorUtils
 
getDaVinciPushStatusAndDetails(PushStatusStoreReader, String, int, Optional<String>, int, double, boolean) - Static method in class com.linkedin.venice.pushmonitor.PushMonitorUtils
This method checks Da Vinci client push status for the target version from push status store and compute a final status.
getDaVinciPushStatusScanIntervalInSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDaVinciPushStatusScanMaxOfflineInstanceCount() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDaVinciPushStatusScanMaxOfflineInstanceRatio() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDaVinciPushStatusScanNoReportRetryMaxAttempt() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDaVinciPushStatusScanThreadNumber() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'daVinciPushStatusStoreEnabled' field.
getDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'daVinciPushStatusStoreEnabled' field.
getDaVinciPushStatusStoreName(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
getDebug() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getDebugInfo() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
Gets the value of the 'debugInfo' field.
getDebugInfo() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'debugInfo' field.
getDebugInfo() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getDebugInfo() - Static method in class com.linkedin.venice.utils.Utils
 
getDecoderState() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
getDecompressionTimeInNs() - Method in class com.linkedin.venice.router.api.ContentDecompressResult
 
getDecompressionTimeInNs() - Method in class com.linkedin.venice.router.api.VeniceFullHttpResponse
 
getDedicatedConsumerPoolSizeForAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDefaultConfigs() - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
 
getDefaultDeserializationExecutor() - Static method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getDefaultInstance() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
getDefaultInstance() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
getDefaultQOSAllocation() - Static method in class com.linkedin.alpini.base.queuing.AbstractQOS
 
getDefaultReadQuotaPerRouter() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getDefaultTimeoutMillis() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
getDefaultValue() - Method in class com.linkedin.venice.utils.Utils.ConfigEntity
 
getDeferredWrite() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'deferredWrite' field.
getDeferVersionSwap() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'deferVersionSwap' field.
getDefinition() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
Gets the value of the 'definition' field.
getDelayToRebalanceMS() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getDelegateTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
 
getDeletableStoreTopics() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getDeletableStoreTopics(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getDeletedElements() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
getDeletedElementTimestamps() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
getDeletedResource() - Method in class com.linkedin.venice.helix.ResourceAssignment.ResourceAssignmentChanges
 
getDELETEDTS() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Gets the value of the 'DELETED_TS' field.
getDeleting() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Gets the value of the 'deleting' field.
getDeprecatedJobTopicMaxRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDeprecatedJobTopicMaxRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getDeprecatedJobTopicRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDeprecatedJobTopicRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getDerivedSchema(int, int) - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
Retrieve update schema and annotate top-level string array and map field's field update and collection merge operations.
getDerivedSchema(int, int) - Method in class com.linkedin.venice.schema.SchemaData
 
getDerivedSchema(String, int, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getDerivedSchema(String, int, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getDerivedSchema(String, int, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
 
getDerivedSchema(String, String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getDerivedSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Gets the value of the 'derivedSchemaId' field.
getDerivedSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
getDerivedSchemaId() - Method in class com.linkedin.venice.controllerapi.SchemaResponse
 
getDerivedSchemaId(String) - Method in class com.linkedin.venice.schema.SchemaData
 
getDerivedSchemaId(String, String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getDerivedSchemaId(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getDerivedSchemaId(String, String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Look up derived schema id and its corresponding value schema id by given store name and derived schema.
getDerivedSchemaId(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getDerivedSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getDerivedSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getDerivedSchemas() - Method in class com.linkedin.venice.schema.SchemaData
 
getDerivedSchemas(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getDerivedSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getDerivedSchemas(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getDerivedSchemas(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
 
getDerivedSchemas(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getDerivedSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getDerivedSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getDerivedValueSchemaId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
getDesc() - Method in enum com.linkedin.venice.Command
 
getDescription() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
Gets a human readable description of this validation result.
getDescription() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceOuterClass
 
getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
getDescriptorForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
getDescriptorForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
 
getDeserializationExecutor() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getDeserializer() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
 
getDeserializer(int) - Method in class com.linkedin.venice.serialization.avro.AvroSpecificStoreDeserializerCache
 
getDeserializer(int) - Method in class com.linkedin.venice.serialization.AvroStoreDeserializerCache
 
getDeserializer(int) - Method in class com.linkedin.venice.serialization.RawBytesStoreDeserializerCache
 
getDeserializer(int) - Method in interface com.linkedin.venice.serialization.StoreDeserializerCache
 
getDeserializer(int, int) - Method in class com.linkedin.venice.serialization.avro.AvroSpecificStoreDeserializerCache
 
getDeserializer(int, int) - Method in class com.linkedin.venice.serialization.AvroStoreDeserializerCache
 
getDeserializer(int, int) - Method in class com.linkedin.venice.serialization.RawBytesStoreDeserializerCache
 
getDeserializer(int, int) - Method in interface com.linkedin.venice.serialization.StoreDeserializerCache
 
getDeserializer(Schema, Schema) - Static method in class com.linkedin.davinci.serializer.avro.fast.MapOrderPreservingFastSerDeFactory
 
getDeserializer(Schema, Schema) - Static method in class com.linkedin.davinci.serializer.avro.MapOrderPreservingSerDeFactory
 
getDeserializerFromFactory(Schema, Schema) - Method in class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
 
getDeserializerFromFactory(Schema, Schema) - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
Deprecated.
 
getDestClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
Gets the value of the 'destClusterName' field.
getDestClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
Gets the value of the 'destClusterName' field.
getDestFabric() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getDestination() - Method in class com.linkedin.venice.writer.VeniceWriter
 
getDestroyCallStats() - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
getDestroyTime50Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 50 percentage time to create an object.
getDestroyTime95Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 95 percentage time to create an object.
getDestroyTime99Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 99 percentage time to create an object.
getDestroyTimeAvg() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the average time to create an object.
getDetail() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Gets the value of the 'detail' field.
getDetails() - Method in class com.linkedin.venice.controller.NodeRemovableResult
 
getDetails() - Method in class com.linkedin.venice.controllerapi.NodeStatusResponse
 
getDetails() - Method in class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
 
getDictionaryRetrievalTimeMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getDisableDavinciPushStatusStore() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'disableDavinciPushStatusStore' field.
getDisabledPartitionsMap(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Returns a list of disabled partitions in an instance.
getDisabledPartitionsMap(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
getDisabledPartitionStats(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getDisabledReplicaEnablerServiceIntervalMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDisabledReplicaEnablerServiceIntervalMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getDisabledRoutes() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getDisabledRoutes() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getDisableMetaStore() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'disableMetaStore' field.
getDisableReplicaCallback(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getDisableStoreView() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getDiskFullThreshold() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDiskHealthCheckIntervalInMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDiskHealthCheckTimeoutInMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDiskQuotaUsage() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
getDiskStatus() - Method in class com.linkedin.venice.utils.DiskUsage
 
getDiskUsage() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getDispatchMinimumMillis() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
getDivProducerStateMaxAgeMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDnsCacheRefreshIntervalInMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getDoc() - Method in class com.linkedin.venice.utils.Utils.ConfigEntity
 
getDotProductCount() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getDotProductParam() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
Gets the value of the 'dotProductParam' field.
getDouble(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getDouble(String, double) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getDoUpdateSupersetSchemaID() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Gets the value of the 'doUpdateSupersetSchemaID' field.
getDrainerForConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
getDrainerIndexForConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
getDrainerPoolSizeSortedInput() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDrainerPoolSizeUnsortedInput() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getDummyCommand() - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
getDummyContent() - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
getDummyKey() - Static method in class com.linkedin.venice.utils.PubSubHelper
 
getDummyKey(boolean) - Static method in class com.linkedin.venice.utils.PubSubHelper
 
getDummyPubSubMessage(boolean) - Static method in class com.linkedin.venice.utils.PubSubHelper
 
getDummyValue() - Static method in class com.linkedin.venice.utils.PubSubHelper
 
getDummyValue(long) - Static method in class com.linkedin.venice.utils.PubSubHelper
 
getDuplicateKeyWithDistinctCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getDuplicateKeyWithDistinctCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getDuplicateKeyWithDistinctValueCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getDuplicateKeyWithDistinctValueCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getDuplicateKeyWithDistinctValueCount() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getDuplicateKeyWithDistinctValueCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getDuplicateMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
getDurationInSec(OfflinePushStatus) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getElapsedTimeInMs(long) - Static method in class com.linkedin.venice.utils.LatencyUtils
 
getElapsedTimeMillis() - Method in class com.linkedin.alpini.base.misc.TouchTimer
Return the total time elapsed between the first and last events.
getElapsedTimeNanos() - Method in class com.linkedin.alpini.base.misc.TouchTimer
Return the total time elapsed between the first and last events.
getElapsedTimeSinceLastPollInMs() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
getEmergencySourceRegion() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getEmergencySourceRegion(String) - Method in interface com.linkedin.venice.controller.Admin
Return the emergency source region configuration.
getEmergencySourceRegion(String) - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getEmergencySourceRegion(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getEmergencySourceRegion(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Gets the value of the 'enabled' field.
getEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Gets the value of the 'enabled' field.
getEnabledSystemStoreTypes(Store) - Static method in enum com.linkedin.venice.common.VeniceSystemStoreType
Get a list of enabled Venice system store types based on the given regular Venice Store object.
getEnableReads() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'enableReads' field.
getEnableReads() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getEnableReads() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'enableReads' field.
getEnableReads() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'enableReads' field.
getEnableWrites() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'enableWrites' field.
getEnableWrites() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getEnableWrites() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'enableWrites' field.
getEnableWrites() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'enableWrites' field.
getEncodedState() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
getEncodedState() - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
 
getEndingOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
Returns the ending offset for the split
getEndOffset(String, int) - Method in class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
Get the end offset of a topic partition
getEndOfPush() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'endOfPush' field.
getEndOfPushTimestamp() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getEndOfPushTimestamp() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'endOfPushTimestamp' field.
getEngineTaskConfigProvider() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
getEntryFromDnsCache(String) - Method in class com.linkedin.venice.httpclient.CachedDnsResolver
 
getEnumValuesArray(Class<V>) - Static method in class com.linkedin.venice.utils.EnumUtils
Lots of defensive coding to ensure that control message type values are: 1.
getEnv() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getEnvelopeDeserializer(int) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
getEnvelopeDeserializer(int) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
 
getEnvelopeDeserializer(int) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
 
getEnvironment() - Method in class com.linkedin.alpini.io.ExternalCommand
 
getEnvOptions() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getError() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantile
 
getError() - Method in class com.linkedin.alpini.io.ExternalCommand
 
getError() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
getError() - Method in class com.linkedin.venice.datarecovery.Command.Result
 
getError() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
 
getError() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
Gets the value of the 'error' field.
getErrorCode() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 errorCode = 6;
getErrorCode() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
uint32 errorCode = 6;
getErrorCode() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
uint32 errorCode = 6;
getErrorCount() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getErrorCount() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getErrorCount() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getErrorCount() - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
getErrorCountTotal() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getErrorCountTotal() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getErrorFrequency() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getErrorFrequency() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getErrorFrequency() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getErrorFrequency15min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getErrorFrequency15min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getErrorFrequency1min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getErrorFrequency1min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getErrorFrequency5min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getErrorFrequency5min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getErrorInstances() - Method in class com.linkedin.venice.meta.Partition
 
getErrorMessage() - Method in class com.linkedin.davinci.storage.DiskHealthCheckService
 
getErrorMessage() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getErrorMessage() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
string errorMessage = 7;
getErrorMessage() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
string errorMessage = 7;
getErrorMessage() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
string errorMessage = 7;
getErrorMessage(String, String, String) - Static method in exception com.linkedin.venice.exceptions.QuotaExceededException
 
getErrorMessageBytes() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
string errorMessage = 7;
getErrorMessageBytes() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
string errorMessage = 7;
getErrorMessageBytes() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
string errorMessage = 7;
getErrorPartitionAutoResetLimit() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getErrorPartitionProcessingCycleDelay() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getErrorReported() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'errorReported' field.
getErrorStream() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
 
getErrorType() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
getErrorType() - Method in exception com.linkedin.venice.exceptions.VeniceException
Returns the errorType.
getEstimatedObjectSizeOnHeap() - Method in class com.linkedin.venice.message.KafkaKey
 
getEstimatedRecoveryTimeInSeconds() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
getEstimator() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
 
getEtlConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'etlConfig' field.
getETLedProxyUserAccount() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getEtledUserProxyAccount() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
Gets the value of the 'etledUserProxyAccount' field.
getEtledUserProxyAccount() - Method in interface com.linkedin.venice.meta.ETLStoreConfig
 
getEtledUserProxyAccount() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
getEtledUserProxyAccount() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
Gets the value of the 'etledUserProxyAccount' field.
getEtledUserProxyAccount() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Gets the value of the 'etledUserProxyAccount' field.
getETLFileSchema(Schema, Schema) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
getETLFileSchemaWithNullDefaultValue(Schema, Schema) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
getEtlStoreConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getEtlStoreConfig() - Method in interface com.linkedin.venice.meta.Store
 
getEtlStoreConfig() - Method in class com.linkedin.venice.meta.StoreInfo
 
getEtlStoreConfig() - Method in class com.linkedin.venice.meta.SystemStore
 
getEtlStoreConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'etlStoreConfig' field.
getEtlStoreConfig() - Method in class com.linkedin.venice.meta.ZKStore
 
getETLStoreConfig() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'ETLStoreConfig' field.
getEventLoopGroup() - Method in interface com.linkedin.alpini.netty4.misc.EventGroupLoopSupplier
 
getExceedQuotaFlag() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
getExceedQuotaFlag() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
getException() - Method in class com.linkedin.venice.pubsub.adapter.PubSubProducerCallbackSimpleImpl
 
getExceptionThrown() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'exceptionThrown' field.
getExceptionType() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
Deprecated.
getExceptionType() - Method in enum com.linkedin.venice.exceptions.ErrorType
 
getExecuteExistingDelayedTasksAfterShutdownPolicy() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Gets the policy on whether to execute existing delayed tasks even when this executor has been shutdown.
getExecution() - Method in class com.linkedin.venice.controllerapi.routes.AdminCommandExecutionResponse
 
getExecution(Admin) - Method in class com.linkedin.venice.controller.server.AdminCommandExecutionRoutes
No ACL check; any user is allowed to check admin command execution status.
getExecutionId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
Gets the value of the 'executionId' field.
getExecutionId() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
getExecutionId() - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
 
getExecutionId() - Method in class com.linkedin.venice.controllerapi.TrackableControllerResponse
 
getExecutionId(Map<String, Long>) - Static method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
 
getExecutionIdAccessor() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getExecutionStatus() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
getExecutionStatus() - Method in class com.linkedin.venice.routerapi.PushStatusResponse
 
getExecutionStatusByInstanceId(String) - Method in class com.linkedin.venice.meta.Partition
 
getExecutor() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
 
getExecutor() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
 
getExecutorService() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumptionTask
 
getExecutorService(String) - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
getExecutorService(String) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelDualPoolFactory
 
getExistingHttpPipelineInitializer() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getExitCode() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
 
getExpectedChecksum() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getExpectedNumberOfPartitions() - Method in class com.linkedin.venice.meta.PartitionAssignment
 
getExpectedRetentionTimeInMs(Store, HybridStoreConfig) - Static method in class com.linkedin.venice.utils.StoreUtils
The default retention time for the RT topic is defined in PubSubConstants.DEFAULT_TOPIC_RETENTION_POLICY_MS, but if the rewind time is larger than this, then the RT topic's retention time needs to be set even higher, in order to guarantee that buffer replays do not lose data.
getExpectedRouterCount() - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
getExpectedRoutersCount() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
getExpectedRoutersCount() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Get the expected number of routers in the cluster.
getExpectedValue() - Method in class com.linkedin.venice.client.store.predicate.EqualsRelationalOperator
 
getExternalContext() - Method in class com.linkedin.alpini.log.FastLogContext
 
getExternalSupersetSchemaGenerator() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getExtraDetails() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
getExtraDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
Deprecated.
Only used for JSON serialization purposes. Use JobStatusQueryResponse.getOptionalExtraDetails() instead.
getExtraInfo() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
getExtraInfo() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
N.B.: The values in this map conform to ExecutionStatus values.
getExtraInfoUpdateTimestamp() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
getExtraInfoUpdateTimestamp() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
N.B.: Older versions of the controller did not support these timestamps, so this map can be null.
getFabricToExecutionStatusMap() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
getFailedIngestionPartitionCount() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getFailingOffset() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
 
getFailureDetails() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'failureDetails' field.
getFailureReason() - Method in interface com.linkedin.venice.hadoop.jobs.ComputeJob
 
getFailureReason() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
getFairAllocationRatio() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
getFairRatio() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.StaticConfig
 
getFastAvroFieldLimitPerMethod() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getFastAvroGenericDeserializer(Schema, Schema) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
 
getFastAvroGenericSerializer(Schema) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
 
getFastAvroGenericSerializer(Schema, boolean) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
 
getFastAvroSpecificDeserializer(Schema, Class<V>) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
 
getFastClassSchemaWarmupTimeout() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getFatalDataValidationFailureRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getFatalDataValidationFailureRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getField() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
Gets the value of the 'field' field.
getField() - Method in class com.linkedin.venice.compute.protocol.request.Count
Gets the value of the 'field' field.
getField() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
Gets the value of the 'field' field.
getField() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
Gets the value of the 'field' field.
getField(Object, String, int) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
Backport getField() method implementation from GenericData in avro v1.7
getFieldDefault(Schema.Field) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Non-throwing flavor of AvroCompatibilityHelper.getGenericDefaultValue, returns null if there is no default.
getFieldIndex(StructType, String) - Static method in class com.linkedin.venice.hadoop.spark.utils.SparkScalaUtils
Get the index of a field in a StructType.
getFieldName() - Method in class com.linkedin.venice.client.store.predicate.EqualsRelationalOperator
 
getFieldName() - Method in exception com.linkedin.venice.hadoop.exceptions.VeniceSchemaFieldNotFoundException
 
getFieldOperationType(Object) - Static method in enum com.linkedin.venice.schema.writecompute.WriteComputeOperation
 
getFields() - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
 
getFields() - Method in class com.linkedin.venice.status.StatusMessage
Get K-V paris of all the fields in message.
getFields() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
getFilePath() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputPartition
 
getFileSchema(FileSystem, Path) - Static method in class com.linkedin.venice.hadoop.input.recordreader.avro.HdfsAvroUtils
 
getFilledSize() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
 
getFilterChain(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
 
getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.Adler32CheckSum
 
getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
 
getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
 
getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getFinalSegment() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
Gets the value of the 'finalSegment' field.
getFineGrainedPercentileStat(String, int, double) - Static method in class com.linkedin.venice.stats.TehutiUtils
 
getFineGrainedPercentileStat(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
 
getFineGrainedPercentileStatWithAvgAndMax(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
 
getFirst() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Returns the first element in this list.
getFirst() - Method in class com.linkedin.alpini.base.misc.Pair
Return the first value.
getFirst() - Method in class com.linkedin.venice.utils.Pair
Deprecated.
 
getFirstHeader(String) - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
 
getFirstSendHeartbeatException() - Method in class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSender
 
getFirstSendHeartbeatException() - Method in interface com.linkedin.venice.hadoop.heartbeat.PushJobHeartbeatSender
Get first exception encountered while it is sending heartbeats.
getFlushIntervalMs() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getFollowerBytesConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getFollowerHeartbeatTimeStamps() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
getFollowerLag(String) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
 
getFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Measure the offset lag between follower and leader
getFollowerOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getFollowerRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getForkedProcessJvmArgList() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getForkProcessActionLock() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getForRead() - Method in interface com.linkedin.venice.meta.AbstractStore.StoreVersionSupplier
This function will return a list of Versions, which are read-only, and any modification against them will throw UnsupportedOperationException.
getForUpdate() - Method in interface com.linkedin.venice.meta.AbstractStore.StoreVersionSupplier
This function will return a reference to the internal versions structure, and any change applying to the returned object will be reflected in the referenced Store.
getFreePort() - Static method in class com.linkedin.venice.utils.TestUtils
WARNING: The code which generates the free port and uses it must always be called within a try/catch and a loop.
getFullMetricName(String) - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
 
getFullPathForTempSSTFileDir() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
getFullPathForTempSSTFileDir() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getFullPendingQueueServerOORMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getFuture() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getFutureVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
getFutureVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
getFutureVersion() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Result
 
getFutureVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getFutureVersion(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
return Store.NON_EXISTING_VERSION if future version doesn't exist.
getFutureVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getFutureVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getFutureVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller and returns Store.NON_EXISTING_VERSION.
getFutureVersionETLEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
Gets the value of the 'futureVersionETLEnabled' field.
getFutureVersionETLEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getFutureVersionETLEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
Gets the value of the 'futureVersionETLEnabled' field.
getFutureVersionETLEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Gets the value of the 'futureVersionETLEnabled' field.
getFutureVersions(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getFutureVersionsForMultiColos(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getFutureVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getFutureVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getGeneratedSchemaVersion() - Method in class com.linkedin.venice.schema.GeneratedSchemaID
 
getGenericAvroClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getGenericAvroClient(String, DaVinciConfig) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
getGenericAvroClient(String, DaVinciConfig) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
 
getGenericRecordChunkingAdapter() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
getGenericThinClient() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getGetMethod() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
 
getGlobalShutdownDelayMillis() - Static method in class com.linkedin.alpini.base.registry.ResourceRegistry
Get the delay for global shutdown.
getGraveyardCleanupSleepIntervalBetweenListFetchMinutes() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getGroupCount() - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
getGroupCount() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
getGroupIds() - Method in class com.linkedin.venice.fastclient.meta.HelixGroupInfo
 
getGroupName() - Method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper.GroupAndCounterNames
 
getGrpcClientConfig() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getGrpcPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getGrpcStatsContext() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
getGrpcWorkerThreadCount() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getGuid() - Method in class com.linkedin.venice.guid.DeterministicGuidGenerator
 
getGuid() - Method in class com.linkedin.venice.guid.HeartbeatGuidV3Generator
 
getGuid() - Method in class com.linkedin.venice.guid.JavaUtilGuidV4Generator
 
getGUID(VeniceProperties) - Static method in class com.linkedin.venice.guid.GuidUtils
 
getGuidFromCharSequence(CharSequence) - Static method in class com.linkedin.venice.guid.GuidUtils
 
getGuidFromHex(String) - Static method in class com.linkedin.venice.guid.GuidUtils
 
getGUIDString() - Static method in class com.linkedin.venice.guid.GuidUtils
 
getH2ActiveConnections() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getH2ActiveConnections() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getHadamardProductCount() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getHadamardProductParam() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
Gets the value of the 'hadamardProductParam' field.
getHadoopUserCredentials() - Static method in class com.linkedin.venice.hadoop.ssl.UserCredentialsFactory
Get user's credentials from the current Hadoop user group context.
getHandler(Class<T>) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
Get the handler for given Venice message type.
getHandshakesFailed() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Returns the number of handshakes which had resulted in failure.
getHandshakesStarted() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Returns the number of handshakes which have been started.
getHandshakesSuccessful() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Returns the number of handshakes which had resulted in success.
getHealthCheckIntervalMillis() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
getHealthReportCollector() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getHealthyRegions() - Method in class com.linkedin.venice.meta.StoreDataAudit
 
getHeartbeat(String) - Method in class com.linkedin.venice.system.store.MetaStoreReader
 
getHeartbeat(String, String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
getHeartbeatCycleMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHeartbeatFromSystemStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getHeartbeatFromSystemStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getHeartbeatFromSystemStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
Read the latest heartbeat timestamp from system store.
getHeartbeatFromSystemStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getHeartbeatFromSystemStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getHeartbeatInitialDelay() - Method in class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSender
 
getHeartbeatInitialDelay() - Method in interface com.linkedin.venice.hadoop.heartbeat.PushJobHeartbeatSender
 
getHeartbeatKey(String) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
 
getHeartbeatKME(long, LeaderMetadataWrapper, ControlMessage, String) - Static method in class com.linkedin.venice.writer.VeniceWriter
 
getHeartbeatMonitoringService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getHeartbeatSendInterval() - Method in class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSender
 
getHeartbeatSendInterval() - Method in interface com.linkedin.venice.hadoop.heartbeat.PushJobHeartbeatSender
 
getHeartbeatTimeoutMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHeartbeatTimestamp() - Method in class com.linkedin.venice.controllerapi.SystemStoreHeartbeatResponse
 
getHelixAdmin() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getHelixAdminClient() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getHelixClusterZkPath(String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
getHelixDataAccessor() - Method in class com.linkedin.venice.helix.SafeHelixManager
This function is incompatible with the HelixManager interface, since the return type of SafeHelixDataAccessor is not compatible with the return of the unsafe interface, which is a HelixDataAccessor.
getHelixGroupId() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getHelixGroupInfo() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'helixGroupInfo' field.
getHelixGroupInfoMap() - Method in class com.linkedin.venice.fastclient.meta.HelixGroupInfo
 
getHelixGroupSelectionStrategy() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHelixManager() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getHelixNodeIdentifier(String, int) - Static method in class com.linkedin.venice.utils.Utils
 
getHelixParticipationService() - Method in class com.linkedin.venice.server.VeniceServer
 
getHelixPropertyStore() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getHelixReadOnlyStoreRepository() - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
getHelixRebalanceAlg() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getHelixSendMessageTimeoutMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getHelixStateByInstanceId(String) - Method in class com.linkedin.venice.meta.Partition
Find the status of given instance in this partition.
getHelixVeniceClusterResources(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getHelpText() - Method in enum com.linkedin.venice.Arg
 
getHexFromGuid(GUID) - Static method in class com.linkedin.venice.guid.GuidUtils
 
getHitCount() - Method in class com.linkedin.davinci.store.cache.backend.StoreCacheStats
 
getHitRate() - Method in class com.linkedin.davinci.store.cache.backend.StoreCacheStats
 
getHost() - Method in class com.linkedin.venice.meta.Instance
 
getHostLevelIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getHostname() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHostname() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getHostName() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Gets the value of the 'hostName' field.
getHostName() - Static method in class com.linkedin.venice.utils.Utils
Get the node's host name.
getHostPatternForDnsCache() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHosts() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
 
getHostUrl(boolean) - Method in class com.linkedin.venice.meta.Instance
 
getHttp2ChannelGroup() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getHttp2ChannelGroup() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getHttp2Headers() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getHttp2HeaderTableSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getHttp2HeaderTableSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttp2InitialWindowSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getHttp2InitialWindowSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttp2MaxConcurrentStreams() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getHttp2MaxConcurrentStreams() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttp2MaxFrameSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getHttp2MaxFrameSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttp2MaxHeaderListSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getHttp2MaxHeaderListSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttp2PingSendHandler() - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
getHttp2PipelineInitializerBuilderSupplier() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
getHttp2PipelineInitializerBuilderSupplier() - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
getHttp2Settings() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getHttp2SettingsFrameLogger() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getHttp2SettingsFrameLogger() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getHttpasyncclientConnectionWarmingExecutorThreadNum() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpasyncclientConnectionWarmingLowWaterMark() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpasyncclientConnectionWarmingNewInstanceDelayJoinMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpasyncclientConnectionWarmingSleepIntervalMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpasyncclientConnectionWarmingSocketTimeoutMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpClient5PoolSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpClient5TotalIOThreadCount() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpClientForHost(String) - Method in class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
 
getHttpClientPoolSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getHttpMethod() - Method in enum com.linkedin.venice.controllerapi.ControllerRoute
 
getHttpMethod() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
getHttpMethod() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getHttpMethod() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
getHttpResponseStatus() - Method in exception com.linkedin.venice.exceptions.VeniceRouterException
 
getHttpResponseStatus() - Static method in exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
 
getHttpStatus() - Method in exception com.linkedin.venice.client.exceptions.VeniceClientHttpException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.PartitionerSchemaMismatchException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.QuotaExceededException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.ResourceStillExistsException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceAclException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceException
If this exception is caught in handling an http request, what status code should be returned? Exceptions that extend VeniceException can override this for different behavior
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceHttpException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceNoClusterException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceUnsupportedOperationException
 
getHttpStatusCode() - Method in exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
 
getHybrid() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'hybrid' field.
getHybrid() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'hybrid' field.
getHybridBufferReplayPolicy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getHybridConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'hybridConfig' field.
getHybridConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'hybridConfig' field.
getHybridDataReplicationPolicy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getHybridFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getHybridFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getHybridFollowerOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getHybridLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getHybridLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getHybridLeaderOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getHybridOffsetLagThreshold() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getHybridQuotaMonitorTask() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
 
getHybridQuotaReplicaStatus(String, int) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
 
getHybridQuotaViolatedStores() - Method in class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
Get list of quota exceeded stores from local memory cache.
getHybridRewindSeconds() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getHybridStoreConfig() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'hybridStoreConfig' field.
getHybridStoreConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getHybridStoreConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getHybridStoreConfig() - Method in interface com.linkedin.venice.meta.Store
 
getHybridStoreConfig() - Method in class com.linkedin.venice.meta.StoreInfo
 
getHybridStoreConfig() - Method in class com.linkedin.venice.meta.SystemStore
 
getHybridStoreConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'hybridStoreConfig' field.
getHybridStoreConfig() - Method in interface com.linkedin.venice.meta.Version
 
getHybridStoreConfig() - Method in class com.linkedin.venice.meta.VersionImpl
 
getHybridStoreConfig() - Method in class com.linkedin.venice.meta.ZKStore
 
getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'hybridStoreDiskQuotaEnabled' field.
getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'hybridStoreDiskQuotaEnabled' field.
getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'hybridStoreDiskQuotaEnabled' field.
getHybridStoreOverheadBypass() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'hybridStoreOverheadBypass' field.
getHybridStoreOverheadBypass() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getHybridStoreOverheadBypass() - Method in class com.linkedin.venice.meta.StoreInfo
 
getHybridStoreQuotaStatus(String) - Method in class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
Get hybrid store quota status from local memory cache for specific resource name.
getHybridTimeLagThreshold() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getIcProvider() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getIcProvider() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getId() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
Gets the value of the 'id' field.
getId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
getId() - Method in class com.linkedin.venice.controllerapi.SchemaResponse
 
getId() - Method in class com.linkedin.venice.meta.Partition
 
getId() - Method in class com.linkedin.venice.schema.SchemaEntry
 
getIdentityParserClassName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getIdentityParserClassName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getIdentityParserClassName() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getIdleConnectionToServerCleanupThresholdMins() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getIdleCount() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the number of objects that are idle(not checked out) in the pool.
getIdleTime() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getIdx() - Method in class com.linkedin.venice.schema.rmd.v1.ElementTimestampAndIdx
 
getIfPresent(K) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
getIfPresent(K) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns the value associated with the key in this cache, or null if there is no cached value for the key.
getIgnoredResult() - Static method in class com.linkedin.davinci.replication.merge.MergeConflictResult
 
getIncrementalPushEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'incrementalPushEnabled' field.
getIncrementalPushEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'incrementalPushEnabled' field.
getIncrementalPushEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'incrementalPushEnabled' field.
getIncrementalPushEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'incrementalPushEnabled' field.
getIncrementalPushInfo() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'incrementalPushInfo' field.
getIncrementalPushJobTimeInMs(String) - Static method in class com.linkedin.venice.pushmonitor.StatusSnapshot
Incremental push job version id follows such pattern: timestampInMs_hadoopClusterName_jobExecutionId
getIncrementalPushPolicy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'incrementalPushPolicy' field.
getIncrementalPushPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'incrementalPushPolicy' field.
getIncrementalPushPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'incrementalPushPolicy' field.
getIncrementalPushPolicyToApply() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Gets the value of the 'incrementalPushPolicyToApply' field.
getIncrementalPushPolicyToFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Gets the value of the 'incrementalPushPolicyToFilter' field.
getIncrementalPushStatus(PartitionAssignment, String) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
Returns map of partitionId -> list of status history for all working replicas of that partition
getIncrementalPushStatusAndDetails(String, String, HelixCustomizedViewOfflinePushRepository) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getIncrementalPushStatusAndDetails(String, String, HelixCustomizedViewOfflinePushRepository) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Returns incremental push's status read from (ZooKeeper backed) OfflinePushStatus
getIncrementalPushStatusAndDetails(String, String, HelixCustomizedViewOfflinePushRepository) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getIncrementalPushStatusFromPushStatusStore(String, String, HelixCustomizedViewOfflinePushRepository, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getIncrementalPushStatusFromPushStatusStore(String, String, HelixCustomizedViewOfflinePushRepository, PushStatusStoreReader) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Returns incremental push's status read from push status store
getIncrementalPushStatusFromPushStatusStore(String, String, HelixCustomizedViewOfflinePushRepository, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getIncrementalPushVersion() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
getIncrementalPushVersion() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getIncrementalPushVersion() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
getIncrementalPushVersion() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
 
getIncrementalPushVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
Right now, it will return the latest version recorded in parent controller.
getIncrementalPushVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getIncrementalPushVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
A couple of extra checks are needed in parent controller 1.
getIncrementalPushVersions() - Method in class com.linkedin.venice.controllerapi.IncrementalPushVersionsResponse
 
getIndex(String) - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
getIngestingPartitionCount() - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
getIngestingTopicsWithVersionStatusNotOnline() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getIngestingTopicsWithVersionStatusNotOnline() - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Get topic names that are currently maintained by the ingestion service with corresponding version status not in an online state.
getIngestionActionFromRequest(HttpRequest) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
getIngestionApplicationPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getIngestionBackend() - Method in class com.linkedin.davinci.DaVinciBackend
 
getIngestionBackend() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
getIngestionBackend() - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
getIngestionBackend() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getIngestionHeartbeatIntervalMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getIngestionInfoFromConsumer(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
getIngestionInfoFromConsumer(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
getIngestionInfoFromConsumer(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
getIngestionIsolationPropertyMap() - Static method in class com.linkedin.venice.utils.TestUtils
 
getIngestionMemoryLimit() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getIngestionMode() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getIngestionNotifier() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getIngestionServicePort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getIngestionTask() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
getIngestionTask() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getIngestionTaskErroredGauge() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getIngestionTaskMaxIdleCount() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getIngestionTaskName() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getIngestionTaskPushTimeoutGauge() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getInnerClientConfig() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getInnerStoreClient() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
getInputAvailable() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
getInputAvailable() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
getInputBuffer() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
getInputBuffer() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
getInputDataInfoProvider() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
getInputFileDataSize() - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
Gets the value of the 'inputFileDataSize' field.
getInputFileDataSizeInBytes() - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
 
getInputLastModificationTime(String) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
getInputLastModificationTime(String) - Method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
 
getInputLastModificationTime(String) - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
 
getInputModificationTime() - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
 
getInputStream() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
 
getInputURI(VeniceProperties) - Method in class com.linkedin.venice.hadoop.VenicePushJob
Get input path from the properties; Check whether there is sub-directory in the input directory
getInstance() - Static method in class com.linkedin.alpini.base.concurrency.impl.CancelledAsyncFuture
 
getInstance() - Static method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getInstance() - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
getInstance() - Static method in class com.linkedin.davinci.replication.merge.MergeConflictResolverFactory
 
getInstance() - Static method in class com.linkedin.venice.guid.HeartbeatGuidV3Generator
 
getInstance() - Static method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
 
getInstance() - Method in class com.linkedin.venice.helix.Replica
 
getInstance() - Static method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
 
getInstance() - Static method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
 
getInstance() - Static method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
 
getInstance() - Static method in class com.linkedin.venice.serialization.RawBytesStoreDeserializerCache
 
getInstance() - Static method in class com.linkedin.venice.utils.ObjectMapperFactory
 
getInstance(int, int, byte[]) - Method in class com.linkedin.venice.helix.AbstractSchemaEntrySerializer
 
getInstance(int, int, byte[]) - Method in class com.linkedin.venice.helix.DerivedSchemaEntrySerializer
 
getInstance(int, int, byte[]) - Method in class com.linkedin.venice.helix.ReplicationMetadataSchemaEntrySerializer
 
getInstance(AbstractAvroStoreClient) - Static method in class com.linkedin.venice.store.StoreStateReader
 
getInstance(ClientConfig) - Static method in class com.linkedin.venice.store.StoreStateReader
 
getInstance(ClientConfig, VeniceProperties) - Static method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getInstance(ClientConfig, VeniceProperties, ICProvider) - Static method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getInstance(CheckSumType) - Static method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
getInstance(CheckSumType, byte[]) - Static method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
getInstanceFromHelixInstanceName(String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
getInstanceGroupId(String) - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
getInstanceGroupId(String) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
getInstanceGroupIdMapping() - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
getInstanceHealthMonitor() - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
getInstanceHealthMonitor() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getInstanceId() - Method in class com.linkedin.venice.meta.ReplicaDetail
 
getInstanceId() - Method in class com.linkedin.venice.meta.UncompletedReplica
 
getInstanceId() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
getInstanceId() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
getInstanceIdFromReplicaId(String) - Static method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
getInstanceName() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getInstances() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
Gets the value of the 'instances' field.
getInstancesInCluster(String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Get a list of instances under a cluster.
getInstancesInCluster(String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
getInstancesInState(HelixState) - Method in class com.linkedin.venice.meta.Partition
 
getInstancesInState(ExecutionStatus) - Method in class com.linkedin.venice.meta.Partition
 
getInstancesStatusMap() - Method in class com.linkedin.venice.controllerapi.MultiNodesStatusResponse
 
getInstanceToHelixStateMap() - Method in class com.linkedin.venice.meta.Partition
 
getInstanceType() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getInt(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getInt(CharSequence, int) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getInt(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getInt(String, int) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getInterceptors() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
 
getInternalProducer() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
getInternalStorageEngineFactory(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.storage.StorageService
This method should ideally be Private, but marked as public for validating the result.
getIntHeaderFromByteBuffer(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
Extract an integer header from the ByteBuffer provided.
getIntValue() - Method in class com.linkedin.alpini.base.hash.Crc32C
 
getInUseSchemaIds(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getInUseSchemaIds(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getInUseValueSchemaIds() - Method in class com.linkedin.venice.controllerapi.SchemaUsageResponse
 
getInUseValueSchemaIds(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getInUseValueSchemaIds(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getInUseValueSchemaIds(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getIoThreadCountInPoolMode() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getIsBatchRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isBatchRequest = 9;
getIsBatchRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
bool isBatchRequest = 9;
getIsBatchRequest() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
bool isBatchRequest = 9;
getIsChunk() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
Gets the value of the 'isChunk' field.
getIsDataRecoveryComplete() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Gets the value of the 'isDataRecoveryComplete' field.
getIsIncrementalPushEnabled() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'isIncrementalPushEnabled' field.
getIsLastVersionSwapMessageFromRealTimeTopic() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Gets the value of the 'isLastVersionSwapMessageFromRealTimeTopic' field.
getIsLatchReleased() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'isLatchReleased' field.
getIsMigrating() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'isMigrating' field.
getIsolatedIngestionServiceProcess() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
getIsPositive() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'isPositive' field.
getIsReadyLatch() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getIsRegistered() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'isRegistered' field.
getIsRepush() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Gets the value of the 'isRepush' field.
getIsRetryRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isRetryRequest = 8;
getIsRetryRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
bool isRetryRequest = 8;
getIsRetryRequest() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
bool isRetryRequest = 8;
getIsStreamingRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isStreamingRequest = 7;
getIsStreamingRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
bool isStreamingRequest = 7;
getIsStreamingRequest() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
bool isStreamingRequest = 7;
getIsStreamingResponse() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
bool isStreamingResponse = 5;
getIsStreamingResponse() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
bool isStreamingResponse = 5;
getIsStreamingResponse() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
bool isStreamingResponse = 5;
getJavaMajorVersion() - Static method in class com.linkedin.venice.utils.Utils
 
getJettyConfigOverrides() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getJobClientFromConfig(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.engine.DefaultHadoopJobClientProvider
 
getJobClientFromConfig(JobConf) - Method in interface com.linkedin.venice.hadoop.mapreduce.engine.HadoopJobClientProvider
 
getJobConf() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
getJobDurationInMs() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'jobDurationInMs' field.
getJobName() - Method in interface com.linkedin.venice.hadoop.engine.EngineTaskConfigProvider
 
getJobName() - Method in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
 
getJobName() - Method in class com.linkedin.venice.hadoop.spark.engine.SparkEngineTaskConfigProvider
 
getJobProperties() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
getJobProperties() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
getJobProps() - Method in interface com.linkedin.venice.hadoop.engine.EngineTaskConfigProvider
 
getJobProps() - Method in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
 
getJobProps() - Method in class com.linkedin.venice.hadoop.spark.engine.SparkEngineTaskConfigProvider
 
getKafkaAdminClass() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getKafkaAdminClass() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getKafkaBootstrapServer() - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
 
getKafkaBootstrapServers() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getKafkaBootstrapServers() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
getKafkaBootstrapServers() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getKafkaBootstrapServers() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getKafkaBootstrapServers() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
Test methods
getKafkaBootstrapServers(boolean) - Method in interface com.linkedin.venice.controller.Admin
Return the ssl or non-ssl bootstrap servers based on the given flag.
getKafkaBootstrapServers(boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getKafkaBootstrapServers(boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getKafkaBrokerUrl() - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
getKafkaBrokerUrl() - Method in class com.linkedin.venice.meta.StoreInfo
 
getKafkaClusterAliasToIdMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaClusterIdToAliasMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaClusterIdToUrlMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaClusterMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaClusterUrlResolver() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
Used to convert from an alternative Kafka URL to the one used in this server instance.
getKafkaClusterUrlToAliasMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaClusterUrlToIdMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaConsumerConfigsForLocalConsumption() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getKafkaConsumerConfigsForRemoteConsumption() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getKafkaEmptyPollSleepMs() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchMaxSizePerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchMaxTimeMS() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchMinSizePerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchPartitionMaxSizePerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchQuotaBytesPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchQuotaRecordPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchQuotaTimeWindow() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchQuotaUnorderedBytesPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaFetchQuotaUnorderedRecordPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaMaxPollRecords() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getKafkaMessageEnvelope(MessageType, boolean, int, boolean, LeaderMetadataWrapper, long) - Method in class com.linkedin.venice.writer.VeniceWriter
A utility function to centralize some boiler plate code for the instantiation of SpecificRecord classes holding the content of our Kafka values.
getKafkaMinLogCompactionLagInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getKafkaMinLogCompactionLagInMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getKafkaReadCycleDelayMs() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaReadOnlyClass() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getKafkaReadOnlyClass() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getKafkaReplicationFactor() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getKafkaReplicationFactorRTTopics() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getKafkaSaslConfig() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getKafkaSaslMechanism() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getKafkaSecurityProtocol() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getKafkaSecurityProtocol() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getKafkaSecurityProtocol(String) - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getKafkaSourceRegion() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getKafkaSSLConfig() - Method in class com.linkedin.venice.SSLConfig
 
getKafkaStoreIngestionService() - Method in class com.linkedin.venice.server.VeniceServer
 
getKafkaTopic() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
Gets the value of the 'kafkaTopic' field.
getKafkaTopic() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getKafkaTopic() - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
 
getKafkaTopic() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getKafkaTopic() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
getKafKaTopic() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Result
 
getKafkaTopicConfigs(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
No ACL check; any user is allowed to check topic configs.
getKafkaTopicConfigs(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getKafkaUrl() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
getKafkaValueSerializer() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getKafkaValueSerializer() - Method in class com.linkedin.venice.controller.VeniceControllerService
 
getKafkaValueSerializer(JobConf) - Static method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputUtils
 
getKafkaVersionTopic() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getKafkaWriteOnlyClass() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getKafkaWriteOnlyClass() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getKey() - Method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
 
getKey() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
getKey() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Gets the value of the 'key' field.
getKey() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Gets the value of the 'key' field.
getKey() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext.KeyInfo
 
getKey() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
Gets the value of the 'key' field.
getKey() - Method in class com.linkedin.venice.message.KafkaKey
 
getKey() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getKey() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
getKey() - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
 
getKey() - Method in class com.linkedin.venice.utils.KeyAndValueSchemas
 
getKey() - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
getKey(ProducerMetadata) - Method in interface com.linkedin.venice.writer.VeniceWriter.KeyProvider
 
getKeyBuffer() - Method in class com.linkedin.venice.router.api.RouterKey
 
getKeyBytes() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getKeyBytes() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Gets the value of the 'keyBytes' field.
getKeyBytes() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
 
getKeyBytes() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
 
getKeyBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for batch get
getKeyBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
used for batch get
getKeyBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
used for batch get
getKeyBytes() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Gets the value of the 'keyBytes' field.
getKeyBytes(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
Return a serialized output key
getKeyBytes(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
 
getKeyBytesFromUrlKeyString(String) - Static method in class com.linkedin.venice.listener.request.GetRouterRequest
 
getKeyCount() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
 
getKeyCount() - Method in class com.linkedin.venice.listener.request.MultiKeyRouterRequestWrapper
 
getKeyCount() - Method in class com.linkedin.venice.listener.request.RouterRequest
 
getKeyCount(OptimizedBinaryDecoder) - Method in class com.linkedin.venice.router.RouterThrottleHandler
Return number of elements in Avro serialized array of records.
getKeyHeaderByte() - Method in enum com.linkedin.venice.kafka.protocol.enums.MessageType
 
getKeyHeaderByte() - Method in class com.linkedin.venice.message.KafkaKey
The key header byte is the first byte in the content of the Kafka key.
getKeyIndex() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Gets the value of the 'keyIndex' field.
getKeyIndex() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
Gets the value of the 'keyIndex' field.
getKeyIndex() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Gets the value of the 'keyIndex' field.
getKeyIndex() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Gets the value of the 'keyIndex' field.
getKeyIndex(ComputeResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
 
getKeyIndex(MultiGetResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
 
getKeyIndex(ENVELOPE) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
getKeyLength() - Method in class com.linkedin.venice.message.KafkaKey
 
getKeyManagerAlgorithm() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getKeyManagers(SSLFactory) - Static method in class com.linkedin.venice.grpc.GrpcSslUtils
 
getKeyManagers(SSLFactory, String) - Static method in class com.linkedin.venice.grpc.GrpcSslUtils
 
getKeyName() - Method in exception com.linkedin.venice.exceptions.MissingKeyInStoreMetadataException
 
getKeyOutputSchema() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
This will be the type returned by the DaVinciClient's read operations.
getKeyPassphrase() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getKeys() - Method in class com.linkedin.venice.listener.request.MultiKeyRouterRequestWrapper
 
getKeySchema() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
getKeySchema() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
getKeySchema() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
getKeySchema() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
getKeySchema() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
Returns Key schema of the store.
getKeySchema() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getKeySchema() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Deprecated.
This method is considered deprecated. Please use StoreSchemaFetcher.getKeySchema() to fetch key schema instead.
getKeySchema() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
Deprecated.
getKeySchema() - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
getKeySchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Gets the value of the 'keySchema' field.
getKeySchema() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
getKeySchema() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getKeySchema() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getKeySchema() - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getKeySchema() - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
 
getKeySchema() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'keySchema' field.
getKeySchema() - Method in class com.linkedin.venice.schema.SchemaData
 
getKeySchema() - Method in interface com.linkedin.venice.schema.SchemaReader
 
getKeySchema() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
getKeySchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
Route to handle retrieving key schema request.
getKeySchema(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getKeySchema(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getKeySchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
This function is used to retrieve key schema for the given store.
getKeySchema(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
This function is used to retrieve key schema for the given store.
getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
Get key schema for the given store.
getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getKeySchema(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getKeySchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Get key schema for the given store.
getKeySchema(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getKeySchema(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getKeySchema(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getKeySchemaMap() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
Gets the value of the 'keySchemaMap' field.
getKeySchemaMap() - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
Gets the value of the 'keySchemaMap' field.
getKeySerializer() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getKeySerializer(Schema) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getKeySerializer(Schema) - Method in class com.linkedin.venice.fastclient.DispatchingVsonStoreClient
Deprecated.
 
getKeySerializerForRequest() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
This function will try to initialize the store client at most once in a blocking fashion, and if the init fails, one async thread will be kicked off to init the store client periodically until the init succeeds.
getKeySerializerWithoutRetry() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getKeySize() - Method in class com.linkedin.venice.router.api.RouterKey
 
getKeySizeList() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getKeyStoreData() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getKeyStoreData() - Method in class com.linkedin.venice.security.SSLConfig
 
getKeyStoreFilePath() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getKeyStoreFilePath() - Method in class com.linkedin.venice.security.SSLConfig
 
getKeyStorePassword() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getKeyStorePassword() - Method in class com.linkedin.venice.security.SSLConfig
 
getKeyStorePassword() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getKeyStorePath() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getKeyStoreType() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getKeyStoreType() - Method in class com.linkedin.venice.security.SSLConfig
 
getKeyStoreType() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getKeyString() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for single get
getKeyString() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
used for single get
getKeyString() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
used for single get
getKeyStringBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for single get
getKeyStringBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
used for single get
getKeyStringBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
used for single get
getKeyStrings() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
Gets the value of the 'keyStrings' field.
getKeyStrings() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
Gets the value of the 'keyStrings' field.
getKeyStrings() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
Gets the value of the 'keyStrings' field.
getKeysWithChunkIdSuffix() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
Gets the value of the 'keysWithChunkIdSuffix' field.
getKeyType(MessageType, int) - Static method in interface com.linkedin.venice.chunking.ChunkKeyValueTransformer
 
getLagCaughtUp() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'lagCaughtUp' field.
getLargeBatchRequestSplitThreshold() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
getLargestUsedVersionFromStoreGraveyard(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getLargestUsedVersionFromStoreGraveyard(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getLargestUsedVersionFromStoreGraveyard(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
Gets the value of the 'largestUsedVersionNumber' field.
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'largestUsedVersionNumber' field.
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getLargestUsedVersionNumber() - Method in interface com.linkedin.venice.meta.Store
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.StoreInfo
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.SystemStore
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'largestUsedVersionNumber' field.
getLargestUsedVersionNumber() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.ZKStore
 
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'largestUsedVersionNumber' field.
getLargestUsedVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Gets the value of the 'largestUsedVersionNumber' field.
getLargestUsedVersionNumber(String) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
 
getLargestUsedVersionNumber(String) - Method in interface com.linkedin.venice.meta.StoreGraveyard
Retrieve the largest used version number by the given store name from graveyard.
getLast() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Returns the last element in this list.
getLastCheckPointedSSTFileNum() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
getLastExceptionForStore(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
Get the encountered exception during admin message consumption for the given store.
getLastExecutionId() - Method in class com.linkedin.venice.controller.AdminCommandExecutionTracker
 
getLastGeneratedExecutionId(String) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
getLastGeneratedExecutionId(String) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
Get the last id which is generated by execution tracker in the give cluster.
getLastGeneratedExecutionId(String) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
 
getLastIndexOfVersionSeparator(String) - Static method in interface com.linkedin.venice.meta.Version
 
getLastLeaderCompleteStateUpdateInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLastLeaderPersistFuture() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLastNotificationTime() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getLastOffset(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
getLastOffset(String, int) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
getLastOffset(String, int) - Method in class com.linkedin.venice.offsets.DeepCopyOffsetManager
 
getLastOffset(String, int) - Method in class com.linkedin.venice.offsets.InMemoryOffsetManager
 
getLastOffset(String, int) - Method in interface com.linkedin.venice.offsets.OffsetManager
Gets the Last Known persisted offset of this consumer.
getLastQueuedRecordPersistedFuture() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLastRecordProducerTimestamp() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getLastRecordTimestamp() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getLastResetTime() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getLastResetTime() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getLastResetTime() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getLastSucceededExecutionId(String) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
getLastSucceededExecutionId(String) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
Get the id for the last succeed operation in the given cluster.
getLastSucceededExecutionId(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
Get the last succeeded execution id for the given store.
getLastSucceededExecutionId(String) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
 
getLastSucceededExecutionId(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Get last succeeded execution id for a given store; if storeName is null, return the last succeeded execution id for the cluster
getLastSucceededExecutionIdInCluster(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
Get the last succeeded execution id for the given cluster.
getLastSucceededExecutionIdMap(String) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
getLastSucceededExecutionIdMap(String) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
Get the execution id map that contains the last succeeded operation in the given cluster for each store.
getLastSucceededExecutionIdMap(String) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
 
getLastSucceedExecutionId() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getLastSucceedExecutionId() - Method in class com.linkedin.venice.LastSucceedExecutionIdResponse
 
getLastSucceedExecutionId(Admin) - Method in class com.linkedin.venice.controller.server.AdminCommandExecutionRoutes
No ACL check; any user is allowed to check last succeeded execution Id.
getLastSucceedExecutionId(String) - Method in interface com.linkedin.venice.controller.Admin
Get the id of the last succeed execution in this controller.
getLastSucceedExecutionId(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getLastSucceedExecutionId(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getLastSuccessfulOffset() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getLastUpdate() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'lastUpdate' field.
getLastVTProduceCallFuture() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatencyInMS(long) - Static method in class com.linkedin.venice.utils.LatencyUtils
 
getLatestConsumedProducerTimestampWithSubPartition(long, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getLatestConsumedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
Different from the persisted upstream offset map in OffsetRecord, latest consumed upstream offset map is maintained for each individual Kafka url.
getLatestConsumedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
For regular L/F stores without A/A enabled, there is always only one real-time source.
getLatestCoordinate(Integer) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
getLatestCreatedVersion() - Method in class com.linkedin.venice.meta.StoreDataAudit
 
getLatestDerivedSchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
 
getLatestDerivedSchema(String, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getLatestDerivedSchema(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getLatestDerivedSchema(String, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Get the most recent derived schema added to the given store and value schema id
getLatestException() - Method in class com.linkedin.venice.utils.ExceptionCaptorNotifier
 
getLatestFailedPush() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getLatestIgnoredUpstreamRTOffset(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestIncrementalPushVersion(PartitionAssignment) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getLatestMessageConsumedTimestampInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestMessageConsumptionTimestampInMs() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'latestMessageConsumptionTimestampInMs' field.
getLatestOffset() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
getLatestOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
getLatestOffset(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the latest available offset for a PubSub topic partition.
getLatestOffsetBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
getLatestOffsetBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
getLatestOffsetBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
getLatestOffsetBasedOnMetrics(String, PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
getLatestOffsetCached(PubSubTopic, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getLatestOffsets(JobConf) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
 
getLatestOffsetWithRetries(PubSubTopicPartition, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getLatestPersistedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
For A/A, there are multiple entries in upstreamOffsetMap during RT ingestion.
getLatestPersistedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
For L/F or NR, there is only one entry in upstreamOffsetMap whose key is NON_AA_REPLICATION_UPSTREAM_OFFSET_MAP_KEY.
getLatestPolledMessageTimestampInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestProcessedLocalVersionTopicOffset() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestProcessedUpstreamRTOffset(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestProcessedUpstreamRTOffsetMap() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestProcessedUpstreamRTOffsetWithIgnoredMessages(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestProcessedUpstreamRTOffsetWithNoDefault(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestProcessedUpstreamVersionTopicOffset() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestProducerProcessingTimeInMs() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getLatestRTOffsetTriedToProduceToVTMap(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLatestSuccessfulPushVersion() - Method in class com.linkedin.venice.meta.StoreDataAudit
 
getLatestSupersetSchemaId() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'latestSuperSetValueSchemaId' field.
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getLatestSuperSetValueSchemaId() - Method in interface com.linkedin.venice.meta.Store
 
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.StoreInfo
 
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.SystemStore
 
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'latestSuperSetValueSchemaId' field.
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.ZKStore
 
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'latestSuperSetValueSchemaId' field.
getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'latestSuperSetValueSchemaId' field.
getLatestUpdateSchema() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
getLatestUpdateSchema() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getLatestUpdateSchema() - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getLatestUpdateSchema() - Method in interface com.linkedin.venice.schema.SchemaReader
 
getLatestUpdateSchema() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
getLatestUpdateSchemaFromSchemaResponse(MultiSchemaResponse, int) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
 
getLatestValueSchema() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
getLatestValueSchema() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
getLatestValueSchema() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
getLatestValueSchema() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
getLatestValueSchema() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
Returns the latest available Value schema of the store.
getLatestValueSchema() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getLatestValueSchema() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Deprecated.
This method is considered deprecated. Please use StoreSchemaFetcher.getLatestValueSchemaEntry() to fetch latest value schema instead.
getLatestValueSchema() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
Deprecated.
getLatestValueSchema() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
getLatestValueSchema() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getLatestValueSchema() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getLatestValueSchema() - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getLatestValueSchema() - Method in interface com.linkedin.venice.schema.SchemaReader
 
getLatestValueSchema() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
getLatestValueSchemaEntry() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
getLatestValueSchemaEntry() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
 
getLatestValueSchemaId() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
getLatestValueSchemaId() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getLatestValueSchemaId() - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getLatestValueSchemaId() - Method in interface com.linkedin.venice.schema.SchemaReader
Get the latest value schema id.
getLatestValueSchemaId() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
getLatestVersion() - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
 
getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getLatestVersionPromoteToCurrentTimestamp() - Method in interface com.linkedin.venice.meta.Store
 
getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.SystemStore
 
getLatestVersionPromoteToCurrentTimestamp() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.ZKStore
 
getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'latestVersionPromoteToCurrentTimestamp' field.
getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Gets the value of the 'latestVersionPromoteToCurrentTimestamp' field.
getLeaderBytesConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getLeaderBytesProduced() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getLeaderCompleteState() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLeaderCompleteState(boolean) - Static method in enum com.linkedin.venice.writer.LeaderCompleteState
 
getLeaderCompleteStateCheckInFollowerValidIntervalMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getLeaderCompleteStateHeader(LeaderCompleteState) - Static method in class com.linkedin.venice.writer.VeniceWriter
 
getLeaderConsumedUpstreamRTOffset(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLeaderController() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
getLeaderController() - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Query the leader controller of current cluster.
getLeaderController(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
No ACL check; any user is allowed to check leader controller.
getLeaderController(String) - Method in interface com.linkedin.venice.controller.Admin
Get instance of leader controller.
getLeaderController(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getLeaderController(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getLeaderControllerChangeTimeMs() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
getLeaderControllerChangeTimeMs() - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Timestamp in milliseconds of the last time leader controller changed.
getLeaderControllerUrl() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getLeaderDIVCompletionLatencySensor() - Method in class com.linkedin.davinci.stats.DIVStats
 
getLeaderFollowerHelixStateTransitionThreadPool() - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'leaderFollowerModelEnabled' field.
getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'leaderFollowerModelEnabled' field.
getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'leaderFollowerModelEnabled' field.
getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'leaderFollowerModelEnabled' field.
getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'leaderFollowerModelEnabled' field.
getLeaderFollowerNotifiers() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getLeaderFollowerState() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLeaderFollowerState() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'leaderFollowerState' field.
getLeaderFollowerThreadPoolStrategy() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getLeaderGUID() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLeaderGUID() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'leaderGUID' field.
getLeaderGUID() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getLeaderHeartbeatTimeStamps() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
getLeaderHostId() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getLeaderHostId() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'leaderHostId' field.
getLeaderHostId() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getLeaderInstance() - Method in class com.linkedin.venice.meta.Partition
 
getLeaderInstance(String, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
Used by tests only.
getLeaderInstance(String, int) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Given resource name and partition number, return the current leader instance.
getLeaderLag(String) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
 
getLeaderMetadataFooter() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Gets the value of the 'leaderMetadataFooter' field.
getLeaderOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'leaderOffset' field.
getLeaderOffset(String, PubSubTopicRepository) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
The caller of this API should be interested in which offset currently leader should consume from now.
getLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getLeaderOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getLeaderPcsList(Collection<PartitionConsumptionState>) - Method in class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
 
getLeaderProducerCompletionLatencySensor() - Method in class com.linkedin.davinci.stats.DIVStats
 
getLeaderProducerFailure() - Method in class com.linkedin.davinci.stats.DIVStats
 
getLeaderRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getLeaderRecordsProduced() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getLeaderSectionIdChecker(String, int) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getLeaderSessionIdChecker() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getLeaderStalledHybridIngestion() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getLeaderState() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getLeaderState() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'leaderState' field.
getLeaderState(int) - Method in class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
 
getLeaderState(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Retrieve current LeaderFollowerState from partition's PCS.
getLeaderStateFromPartitionConsumptionState(String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getLeaderSubPartition(int, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getLeaderTopic() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'leaderTopic' field.
getLeaderTopic() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getLeaderTopic(PubSubTopicRepository) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getLeakedFutureCleanupPollIntervalMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getLeakedFutureCleanupThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getLeakedPushStatusCleanUpServiceSleepIntervalInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getLeakedResourceAllowedLingerTimeInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getLeakedResourceCleanUpIntervalInMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getLength() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
 
getLevel() - Method in class com.linkedin.alpini.log.FastLogger
 
getLevel() - Method in class com.linkedin.venice.utils.ForkedJavaProcess.LogInfo
 
getLevel(Logger) - Static method in class com.linkedin.alpini.consts.Level
 
getLevel0FileNumCompactionTrigger() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getLevel0FileNumCompactionTriggerWriteOnlyVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getLevel0SlowdownWritesTrigger() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getLevel0SlowdownWritesTriggerWriteOnlyVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getLevel0StopWritesTrigger() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getLevel0StopWritesTriggerWriteOnlyVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getLifecycleStats() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get stats collected from AsyncPool.LifeCycle
getLingeringIngestionProcessId(int) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
This method returns lingering forked ingestion process PID if it exists.
getList(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getList(String, List<String>) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getListenerHostname() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getListenerPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getListWithAlternative(String, String, List<String>) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getLiveClusterConfigRepo() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
getLiveInstanceMonitor(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getLiveRouterInstances() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
getLiveRouterInstances() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
 
getLiveRoutersCount() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
Get how many routers live right now.
getLiveRoutersCount() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Get how many routers are living right now in the cluster.
getLoadedStoreUserPartitionMapping() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
getLoadedStoreUserPartitionsMapping() - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
getLoadedStoreUserPartitionsMapping() - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
Get currently loaded store partition mappings.
getLoadedStoreUserPartitionsMapping() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
getLocalAddress() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getLocalAddress() - Method in interface com.linkedin.alpini.router.impl.Router
 
getLocalBrokerFollowerConsumerLatencySensor() - Method in class com.linkedin.davinci.stats.DIVStats
 
getLocalBrokerTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
 
getLocalControllerD2ServiceName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getLocalControllerUrl() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getLocalD2ZkHost() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getLocalD2ZkHosts() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getLocalHighWatermarks() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Gets the value of the 'localHighWatermarks' field.
getLocalRegionName(VeniceProperties, boolean) - Static method in class com.linkedin.venice.utils.RegionUtils
 
getLocalStorageEngine(String) - Method in class com.linkedin.davinci.storage.StorageEngineRepository
 
getLocalTopicManager() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerRepository
By default, return TopicManager for local PubSub cluster.
getLocalVersionTopicOffset() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getLocation() - Method in interface com.linkedin.alpini.router.api.ResourcePath
 
getLocation() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
getLocation() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
getLocation() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
getLocations() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
 
getLockForResource(T) - Method in class com.linkedin.venice.utils.locks.ResourceAutoClosableLockManager
 
getLog() - Method in class com.linkedin.venice.utils.ForkedJavaProcess.LogInfo
 
getLogger(String) - Method in class com.linkedin.alpini.log.FastLogContext
 
getLogger(String, MessageFactory) - Method in class com.linkedin.alpini.log.FastLogContext
 
getLogicalTimestamp() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Gets the value of the 'logicalTimestamp' field.
getLogs() - Method in class com.linkedin.venice.utils.InMemoryLogAppender
 
getLong(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
getLong(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getLong(String, long) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getLongCount() - Method in interface com.linkedin.alpini.base.statistics.LongStats
 
getLongCount() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
 
getLongCount() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
getLongStats() - Method in class com.linkedin.alpini.base.statistics.LongStatsAggregator
 
getLongStatsLowQuantile() - Method in class com.linkedin.alpini.base.statistics.LongStatsAggregatorLowQuantile
 
getLongTailMinimumMillis() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
getLongTailRetryBudgetEnforcementWindowInMs() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getLongTailRetryForBatchGetThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getLongTailRetryForSingleGetThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getLongTailRetryMaxRouteForMultiKeyReq() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
getLongTailRetryMaxRouteForMultiKeyReq() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getLongTailRetryMilliseconds(P, BasicRequest) - Method in interface com.linkedin.alpini.router.api.LongTailRetrySupplier
 
getLongTailRetryMilliseconds(P, BasicRequest) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
getLongTailRetryMilliseconds(P, String) - Method in interface com.linkedin.alpini.router.api.LongTailRetrySupplier
 
getLongTailRetryMilliseconds(P, String) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
getLongTailRetryThresholdForBatchGetInMicroSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getLongTailRetryThresholdForComputeInMicroSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getLongTailRetryThresholdForSingleGetInMicroSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getLongTailRetryThresholdMs() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getLowWatermark() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getLowWatermark() - Method in interface com.linkedin.venice.meta.Store
 
getLowWatermark() - Method in class com.linkedin.venice.meta.StoreInfo
 
getLowWatermark() - Method in class com.linkedin.venice.meta.SystemStore
 
getLowWatermark() - Method in class com.linkedin.venice.meta.ZKStore
 
getLowWatermark() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'lowWatermark' field.
getMagicByte() - Method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
 
getMainIngestionMonitorService() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
getMainIngestionRequestClient() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
getManagementMBean() - Method in class com.linkedin.alpini.log.FastLogContext
 
getManagementMBean() - Method in class com.linkedin.alpini.log.FastLogContextFactory
 
getManagementMBean() - Method in class com.linkedin.alpini.log.FastLogger
 
getManifest() - Method in class com.linkedin.davinci.storage.chunking.ChunkedValueManifestContainer
 
getMap(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getMap(String, Map<String, String>) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getMapperErrorDataModifiedDuringPushJobCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperInvalidInputFileCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperInvalidInputIdxCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperNumRecordsSuccessfullyProcessedCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperSchemaInconsistencyFailureCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperSprayAllPartitionsTriggeredCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperZstdDictTrainFailureCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperZstdDictTrainSkippedCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMapperZstdDictTrainSuccessCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getMaskedValue() - Method in class com.linkedin.alpini.base.hash.Crc32C
 
getMax() - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
getMax() - Method in class com.linkedin.davinci.stats.WritePathLatencySensor
 
getMax(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
 
getMaxBytesPerFile() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
 
getMaxCacheSize() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
getMaxCheckedOut1min() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getMaxChunkSize() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
getMaxChunkSize() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'maxCompactionLagSeconds' field.
getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getMaxCompactionLagSeconds() - Method in interface com.linkedin.venice.meta.Store
 
getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.StoreInfo
 
getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.SystemStore
 
getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ZKStore
 
getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'maxCompactionLagSeconds' field.
getMaxConcurrency() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getMaxConcurrency() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getMaxConcurrency() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getMaxConcurrency15min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getMaxConcurrency15min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getMaxConcurrency1min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getMaxConcurrency1min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getMaxConcurrency5min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getMaxConcurrency5min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getMaxConcurrentResolutions() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMaxConcurrentStreamsLimit() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getMaxConnections() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolWithStats
 
getMaxConnections() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
getMaxConnections() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
getMaxConnections() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
getMaxConnections() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getMaxConnectionsPerRoute() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getMaxConnectionsPerRoute() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
getMaxConnectionsTotal() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getMaxConnectionsTotal() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
getMaxElapsedTimeMSSinceLastPollInConsumerPool() - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
getMaxElapsedTimeMSSinceLastPollInConsumerPool() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
getMaxElapsedTimeMSSinceLastPollInConsumerPool() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
getMaxFileOpeningThreads() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getMaxFutureVersionLeaderFollowerStateTransitionThreadNumber() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getMaxGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
 
getMaxGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupRoundRobinStrategy
 
getMaxGroupPendingRequest() - Method in interface com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategy
Get the maximum of the pending requests among all the groups
getMaxGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
getMaxHeaderSize() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
getMaxHeaderSize() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getMaximum() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the maximum value.
getMaximum() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the maximum value.
getMaximum() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
getMaxInitialLineLength() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
getMaxInitialLineLength() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getMaxKeyCountInMultiGetReq() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMaxLeaderFollowerStateTransitionThreadNumber() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getMaxLogCompactionLagMs() - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
getMaxLogFileNum() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getMaxLogFileSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getMaxMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
 
getMaxMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
getMaxMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
getMaxMessageTimeInMs() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getMaxNumberOfPartitions() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getMaxNumberUnflushedRecords() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getMaxOpenFiles() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getMaxOutgoingConn() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMaxOutgoingConnPerRoute() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMaxPendingAcquires() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolWithStats
 
getMaxPendingAcquires() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
getMaxPendingAcquires() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
getMaxPendingAcquires() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
getMaxPendingAcquires() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getMaxPendingRequest() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMaxPerQueue(QOS) - Method in class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
Returns a queue limit for a specified QOS.
getMaxPoolSize() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the configured maximum pool size.
getMaxQueueLength() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
getMaxQueueLength() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.StaticConfig
 
getMaxRatePerSecond() - Method in class com.linkedin.venice.throttle.EventThrottler
 
getMaxReadCapacityCu() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMaxRequestSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getMaxReuseStreamChannelsLimit() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getMaxRouterReadCapacityCu() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMaxSampleSize() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
 
getMaxSizeForUserPayloadPerMessageInBytes() - Method in class com.linkedin.venice.writer.VeniceWriter
 
getMaxValueSchemaId() - Method in class com.linkedin.venice.schema.SchemaData
 
getMeasurableProducerMetrics() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
 
getMeasurableProducerMetrics() - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
 
getMeasurableProducerMetrics() - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
 
getMeasurableProducerMetrics() - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
 
getMemoryLimit() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getMemoryUsage() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
getMemTableHugePageSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getMemtableSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getMergeResultValueSchema(int, int) - Method in class com.linkedin.davinci.replication.merge.MergeResultValueSchemaResolverImpl
For general purpose, refer to Javadoc of MergeResultValueSchemaResolver.getMergeResultValueSchema(int, int).
getMessage() - Method in class com.linkedin.davinci.listener.response.AdminResponse
 
getMessage() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
getMessage() - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
 
getMessage() - Method in class com.linkedin.davinci.listener.response.TopicPartitionIngestionContextResponse
 
getMessage() - Method in class com.linkedin.venice.datarecovery.Command.Result
 
getMessage() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
 
getMessage() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
getMessage() - Method in exception com.linkedin.venice.exceptions.KafkaConsumerException
 
getMessage() - Method in exception com.linkedin.venice.exceptions.VeniceAclException
 
getMessage() - Method in exception com.linkedin.venice.exceptions.VeniceHttpException
 
getMessage() - Method in exception com.linkedin.venice.exceptions.VeniceMessageException
 
getMessage() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'message' field.
getMessage() - Method in class com.linkedin.venice.listener.response.HttpShortcutResponse
 
getMessageChannel() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getMessageFactory() - Method in class com.linkedin.alpini.log.FastLogger
 
getMessageId() - Method in class com.linkedin.venice.status.StatusMessage
Get Id of message.
getMessageSequenceNumber() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Gets the value of the 'messageSequenceNumber' field.
getMessageSequenceNumber() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'messageSequenceNumber' field.
getMessageSequenceNumber() - Method in class com.linkedin.venice.storage.protocol.ChunkId
Gets the value of the 'messageSequenceNumber' field.
getMessageTimestamp() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Gets the value of the 'messageTimestamp' field.
getMessageTimestamp() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'messageTimestamp' field.
getMessageType() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getMessageType() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Gets the value of the 'messageType' field.
getMessageType() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
Gets the value of the 'messageType' field.
getMessageType() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
Gets the value of the 'messageType' field.
getMessageType() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
Gets the value of the 'messageType' field.
getMessageUnion() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
Gets the value of the 'messageUnion' field.
getMessagingService() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getMetadata() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Gets the value of the 'metadata' field.
getMetadata(String) - Method in interface com.linkedin.davinci.storage.ReadMetadataRetriever
 
getMetadata(String) - Method in class com.linkedin.venice.admin.InMemoryAdminTopicMetadataAccessor
 
getMetadata(String) - Method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
Retrieve the latest metadata map.
getMetadata(String) - Method in class com.linkedin.venice.controller.ZkAdminTopicMetadataAccessor
 
getMetadata(String) - Method in class com.linkedin.venice.listener.ServerReadMetadataRepository
Return the metadata information for the given store.
getMetadataClassName() - Method in exception com.linkedin.venice.exceptions.MissingKeyInStoreMetadataException
 
getMetadataConnWarmupTimeoutInSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getMetadataMap() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
 
getMetadataPartition() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getMetadataRefreshIntervalInSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getMetadataRepo() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getMetadataRepo() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getMetadataRepository() - Method in class com.linkedin.venice.router.RouterServer
 
getMetadataSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Gets the value of the 'metadataSchema' field.
getMetadataType() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
Gets the value of the 'metadataType' field.
getMetadataType() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
Gets the value of the 'metadataType' field.
getMetadataUnion() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
Gets the value of the 'metadataUnion' field.
getMetadataUpdateType() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Gets the value of the 'metadataUpdateType' field.
getMetaStore(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getMetaStoreName(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
getMetaStoreReader() - Method in interface com.linkedin.venice.controller.Admin
 
getMetaStoreReader() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getMetaStoreReader() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getMetaStoreValue(StoreMetaKey, String) - Method in interface com.linkedin.venice.controller.Admin
 
getMetaStoreValue(StoreMetaKey, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getMetaStoreValue(StoreMetaKey, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getMetaStoreWriter() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getMetaStoreWriter() - Method in interface com.linkedin.venice.controller.Admin
Return a MetaStoreWriter, which can be shared across different Venice clusters.
getMetaStoreWriter() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getMetaStoreWriter() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getMetaStoreWriter() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getMetaStoreWriter(String) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
 
getMetaStoreWriterCloseConcurrency() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getMetaStoreWriterCloseConcurrency() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getMetaStoreWriterCloseTimeoutInMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getMetaStoreWriterCloseTimeoutInMS() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getMethod() - Method in class com.linkedin.venice.authorization.AceEntry
 
getMethod() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string method = 10;
getMethod() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
string method = 10;
getMethod() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
string method = 10;
getMethod() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
getMethodBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string method = 10;
getMethodBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
string method = 10;
getMethodBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
string method = 10;
getMethodName() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
The request method name
getMethodName() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
getMetricPrefix() - Method in enum com.linkedin.venice.read.RequestType
 
getMetricPrefix(String, RequestType) - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
getMetrics() - Method in class com.linkedin.alpini.base.misc.Metrics
 
getMetricsMap() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getMetricsRepository() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getMetricsRepository() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getMetricsRepository() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getMetricsRepository() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getMetricsRepository() - Method in class com.linkedin.venice.router.RouterServer
 
getMetricsRepository() - Method in class com.linkedin.venice.server.VeniceServer
 
getMetricsRepository() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getMetricsRepository() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
getMetricsRepository() - Method in interface com.linkedin.venice.tehuti.MetricsAware
 
getMetricsRepository(String) - Static method in class com.linkedin.venice.stats.TehutiUtils
Get default MetricRepository.
getMetricValue(String, List<? extends MetricsAware>, DoubleAccumulator) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
 
getMetricValues(String, String...) - Method in class com.linkedin.venice.fastclient.stats.ClusterStats
 
getMetricValues(String, String...) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
This method is a utility method to get metric values useful in tests and for logging.
getMigrating() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'migrating' field.
getMigrating() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'migrating' field.
getMigrationDestCluster() - Method in class com.linkedin.venice.meta.StoreConfig
 
getMigrationDestCluster() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Gets the value of the 'migrationDestCluster' field.
getMigrationDuplicateStore() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'migrationDuplicateStore' field.
getMigrationDuplicateStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getMigrationDuplicateStore() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'migrationDuplicateStore' field.
getMigrationPushStrategies() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getMigrationSrcCluster() - Method in class com.linkedin.venice.meta.StoreConfig
 
getMigrationSrcCluster() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Gets the value of the 'migrationSrcCluster' field.
getMilliseconds() - Method in class com.linkedin.venice.utils.MockCircularTime
 
getMilliseconds() - Method in class com.linkedin.venice.utils.SystemTime
 
getMilliseconds() - Method in class com.linkedin.venice.utils.TestMockTime
 
getMilliseconds() - Method in interface com.linkedin.venice.utils.Time
 
getMin() - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
getMin(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
 
getMinActiveReplica() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
Deprecated.
getMinActiveReplicas() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getMinActiveReplicas() - Method in interface com.linkedin.venice.meta.Version
 
getMinActiveReplicas() - Method in class com.linkedin.venice.meta.VersionImpl
 
getMinCompactionLagSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'minCompactionLagSeconds' field.
getMinCompactionLagSeconds() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getMinCompactionLagSeconds() - Method in interface com.linkedin.venice.meta.Store
 
getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.StoreInfo
 
getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.SystemStore
 
getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ZKStore
 
getMinCompactionLagSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'minCompactionLagSeconds' field.
getMinConnections() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
getMinConnections() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
getMinConnections() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
getMinGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
 
getMinGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupRoundRobinStrategy
 
getMinGroupPendingRequest() - Method in interface com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategy
Get the minimum of the pending requests among all the groups
getMinGroupPendingRequest() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
getMinimalHttpClient(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
 
getMinimalHttpClient(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>, boolean, long) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
 
getMinimalHttpClient(int, int, Optional<SSLFactory>) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
This function is only being used in test cases.
getMinimalHttpClientWithConnManager(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>, boolean, long) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
 
getMinimum() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the minimum.
getMinimum() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the minimum.
getMinimum() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
getMinInSyncReplicas() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getMinInSyncReplicasAdminTopics() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getMinInSyncReplicasRealTimeTopics() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getMinMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
 
getMinMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
getMinMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
getMinNumberOfPartitions() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getMinNumberOfPartitionsForHybrid() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getMinNumberOfStoreVersionsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getMinNumberOfStoreVersionsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in interface com.linkedin.venice.controller.Admin
 
getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getMinPoolSize() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the configured minimum pool size.
getMinSchemaCountToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getMinSchemaCountToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getMissCount() - Method in class com.linkedin.davinci.store.cache.backend.StoreCacheStats
 
getMissingMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
getModel(String) - Method in class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
 
getModelList(String, int) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
 
getMonitor() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
 
getMsgRate() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
getMultiChunkLargeValueCount() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getMultiClusterConfigFromOneCluster(VeniceControllerConfig) - Static method in class com.linkedin.venice.utils.TestUtils
 
getMultiGetResponseRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getMultiGetTardyLatencyThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getMultiKeyRoutingStrategy() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getName() - Method in class com.linkedin.alpini.log.FastLogger
 
getName() - Method in class com.linkedin.venice.authorization.Principal
 
getName() - Method in class com.linkedin.venice.authorization.Resource
 
getName() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
Gets the value of the 'name' field.
getName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Gets the value of the 'name' field.
getName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
Gets the value of the 'name' field.
getName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Gets the value of the 'name' field.
getName() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
getName() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
getName() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getName() - Method in interface com.linkedin.venice.meta.Store
 
getName() - Method in class com.linkedin.venice.meta.StoreInfo
Store Name
getName() - Method in class com.linkedin.venice.meta.SystemStore
 
getName() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'name' field.
getName() - Method in class com.linkedin.venice.meta.ZKStore
 
getName() - Method in class com.linkedin.venice.persona.Persona
 
getName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapterFactory
 
getName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapterFactory
 
getName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapterFactory
 
getName() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
getName() - Method in interface com.linkedin.venice.pubsub.PubSubAdminAdapterFactory
 
getName() - Method in interface com.linkedin.venice.pubsub.PubSubConsumerAdapterFactory
 
getName() - Method in interface com.linkedin.venice.pubsub.PubSubProducerAdapterFactory
 
getName() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
 
getName() - Method in enum com.linkedin.venice.schema.writecompute.WriteComputeOperation
 
getName() - Method in class com.linkedin.venice.service.AbstractVeniceService
 
getName() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
getName() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'name' field.
getNameValuePairs() - Method in class com.linkedin.venice.controllerapi.QueryParams
 
getNanoseconds() - Method in class com.linkedin.venice.utils.MockCircularTime
 
getNanoseconds() - Method in class com.linkedin.venice.utils.SystemTime
 
getNanoseconds() - Method in class com.linkedin.venice.utils.TestMockTime
 
getNanoseconds() - Method in interface com.linkedin.venice.utils.Time
 
getNativeReplicationEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'nativeReplicationEnabled' field.
getNativeReplicationEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'nativeReplicationEnabled' field.
getNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'nativeReplicationEnabled' field.
getNativeReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'nativeReplicationEnabled' field.
getNativeReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'nativeReplicationEnabled' field.
getNativeReplicationKafkaBootstrapServerAddress(String) - Method in interface com.linkedin.venice.controller.Admin
 
getNativeReplicationKafkaBootstrapServerAddress(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getNativeReplicationKafkaBootstrapServerAddress(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'nativeReplicationSourceFabric' field.
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getNativeReplicationSourceFabric() - Method in interface com.linkedin.venice.meta.Store
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.StoreInfo
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.SystemStore
 
getNativeReplicationSourceFabric() - Method in interface com.linkedin.venice.meta.Version
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.VersionImpl
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.ZKStore
 
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'nativeReplicationSourceFabric' field.
getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'nativeReplicationSourceFabric' field.
getNativeReplicationSourceFabric(String, Store, Optional<String>, Optional<String>, String) - Method in interface com.linkedin.venice.controller.Admin
 
getNativeReplicationSourceFabric(String, Store, Optional<String>, Optional<String>, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Source fabric selection priority: 1.
getNativeReplicationSourceFabric(String, Store, Optional<String>, Optional<String>, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getNativeReplicationSourceFabricAsDefaultForBatchOnly() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getNativeReplicationSourceFabricAsDefaultForHybrid() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getNativeReplicationSourceRegion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Gets the value of the 'nativeReplicationSourceRegion' field.
getNearlineLocalBrokerToReadyToServeLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getNearlineLocalBrokerToReadyToServeLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getNearlineProducerToLocalBrokerLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getNearlineProducerToLocalBrokerLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getNettyGracefulShutdownPeriodSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getNettyIdleTimeInSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getNettyServerToGrpcAddressMap() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig
 
getNettyTimer() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getNettyWorkerThreadCount() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getNewIngestionTask(Store, Version, Properties, BooleanSupplier, VeniceStoreVersionConfig, int, boolean, Optional<ObjectCacheBackend>, Function<Integer, DaVinciRecordTransformer>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory
 
getNewInstance() - Method in enum com.linkedin.venice.common.StoreMetadataType
 
getNewInstance() - Method in enum com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
 
getNewInstance() - Method in enum com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
getNewInstance() - Method in enum com.linkedin.venice.kafka.protocol.enums.ControlMessageType
Simple utility function to generate the right type of control message, based on message type.
getNewInstance() - Method in enum com.linkedin.venice.kafka.protocol.enums.MessageType
Simple utility function to generate the right type of payload, based on message type.
getNewResources() - Method in class com.linkedin.venice.helix.ResourceAssignment.ResourceAssignmentChanges
 
getNewServingVersionTopic() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Gets the value of the 'newServingVersionTopic' field.
getNewSourceTopic() - Method in class com.linkedin.davinci.kafka.consumer.TopicSwitchWrapper
 
getNewStatsContext() - Method in class com.linkedin.venice.listener.StatsHandler
 
getNewValue() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
 
getNext() - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
 
getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.AbstractPollStrategy
 
getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.ArbitraryOrderingPollStrategy
 
getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.BlockingObserverPollStrategy
 
getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.CompositePollStrategy
 
getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.DuplicatingPollStrategy
 
getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.FilteringPollStrategy
 
getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.RandomPollStrategy
 
getNodeCapacityInRcu() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getNodeId() - Method in class com.linkedin.venice.meta.Instance
 
getNodeId() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
getNodeResponsibilityForQuota(PartitionAssignment, String) - Static method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
Recalculates the amount of quota that this node should serve given the partition assignment.
getNodes() - Method in class com.linkedin.venice.controllerapi.MultiNodeResponse
 
getNodeState() - Method in class com.linkedin.venice.controllerapi.NodeReplicasReadinessResponse
 
getNodeUris() - Method in class com.linkedin.venice.d2.D2Server
 
getNodeUris() - Method in class com.linkedin.venice.d2.D2ServerManager
 
getNonExistingKeys() - Method in interface com.linkedin.venice.client.store.streaming.VeniceResponseMap
Retrieve all the non-existing keys known so far, and if the current response is a full response, this will contain all the missing keys in the request.
getNonExistingKeys() - Method in class com.linkedin.venice.client.store.streaming.VeniceResponseMapImpl
 
getNonExistingTopicCheckRetryIntervalSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getNonExistingTopicIngestionTaskKillThresholdSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getNoOpOperation(String) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
 
getNotRepairableSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
 
getNow() - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Non-blocking variant of Future.get()
getNow() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
getNow() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
getNow() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
 
getNow() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
getNullableFieldValueAsList(GenericRecord, Schema.Field) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
getNumber() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getNumber() - Method in interface com.linkedin.venice.meta.Version
 
getNumber() - Method in class com.linkedin.venice.meta.VersionImpl
 
getNumber() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'number' field.
getNumberOfActiveSystemProducers() - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Get the total number of active SystemProducer.
getNumberOfPartition() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getNumberOfPartitions() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
A function which behaves like Map.size(), in the sense that it ignores empty (null) slots in the list.
getNumberOfPartitions() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'numberOfPartitions' field.
getNumberOfPartitions(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
getNumberOfPartitions(String) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
Query number of partition in given kafka topic.
getNumberOfPartitions(String) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
Deprecated.
getNumberOfPartitions(String) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
Deprecated.
getNumberOfPartitions(String) - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
 
getNumberOfPartitions(String) - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
 
getNumberOfSamples() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
getNumberOfToleratedErrors() - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
 
getNumberOfToleratedErrors() - Method in class com.linkedin.venice.pushmonitor.WaitAllPushStatusDecider
 
getNumberOfToleratedErrors() - Method in class com.linkedin.venice.pushmonitor.WaitNMinusOnePushStatusDecider
 
getNumInputFiles() - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
 
getNumOfTotalInstances() - Method in class com.linkedin.venice.meta.Partition
 
getNumPartitions(String) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
Returns the number of partitions for a given db
getNumPartitions(String) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
Returns the number of partitions for a given db
getNumPartitions(String) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
 
getNumSchemaFastClassWarmup() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getNumVersionsToPreserve() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'numVersionsToPreserve' field.
getNumVersionsToPreserve() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getNumVersionsToPreserve() - Method in interface com.linkedin.venice.meta.Store
 
getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.StoreInfo
 
getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.SystemStore
 
getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'numVersionsToPreserve' field.
getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.ZKStore
 
getNumVersionsToPreserve() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'numVersionsToPreserve' field.
getObject() - Method in class com.linkedin.venice.samza.VeniceObjectWithTimestamp
 
getObjectCache() - Method in class com.linkedin.davinci.DaVinciBackend
 
getObjectMapper() - Static method in enum com.linkedin.alpini.base.misc.SimpleJsonMapper
 
getOffLineJobWaitTimeInMilliseconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getOfflinePush(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getOfflinePushAccessor() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getOfflinePushOrThrow(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getOfflinePushOrThrow(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Return a push's status (push status contains the history statuses and current status) and throw exception if it doesn't exist
getOfflinePushOrThrow(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getOfflinePushStatuesParentPath() - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
getOfflinePushStatus(String, String) - Method in class com.linkedin.venice.helix.ParentHelixOfflinePushAccessor
 
getOffLinePushStatus(String, String) - Method in interface com.linkedin.venice.controller.Admin
Query the status of the offline push by given kafka topic.
getOffLinePushStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getOffLinePushStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Queries child clusters for status.
getOffLinePushStatus(String, String, Optional<String>, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getOffLinePushStatus(String, String, Optional<String>, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getOffLinePushStatus(String, String, Optional<String>, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getOfflinePushStatusAccessor() - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
For testing only.
getOfflinePushStatusAndItsPartitionStatuses(String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
getOfflinePushStatusAndItsPartitionStatuses(String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Read one offline push and its partitions status from persistent storage.
getOfflinePushStatusCreationTime(String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
getOfflinePushStatusCreationTime(String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Get the creation time of the given offline push ZK path; the creation time is set by System.currentTimeMillis().
getOfflinePushStatusForStore(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getOfflinePushStatusForStore(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
 
getOfflinePushStatusForStore(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getOfflinePushStrategy() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getOfflinePushStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'offlinePushStrategy' field.
getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getOffLinePushStrategy() - Method in interface com.linkedin.venice.meta.Store
 
getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.SystemStore
 
getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'offLinePushStrategy' field.
getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.ZKStore
 
getOfflinePushStrategyFromInt(int) - Static method in enum com.linkedin.venice.meta.OfflinePushStrategy
 
getOfflineRequestCount() - Method in class com.linkedin.alpini.router.api.Scatter
 
getOfflineRequests() - Method in class com.linkedin.alpini.router.api.Scatter
 
getOffset() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
getOffset() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
 
getOffset() - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
 
getOffset() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Gets the value of the 'offset' field.
getOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
Gets the value of the 'offset' field.
getOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Gets the value of the 'offset' field.
getOffset() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'offset' field.
getOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'offset' field.
getOffset() - Method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
getOffset() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
 
getOffset() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getOffset() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
The offset of the record in the topic/partition.
getOffset() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
getOffset() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
getOffset() - Method in class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
 
getOffset() - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
getOffsetByTime(PubSubTopicPartition, long) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Get offsets for only one partition with a specific timestamp.
getOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
getOffsetLag() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'offsetLag' field.
getOffsetLag() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getOffsetLag(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
getOffsetLag(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the consuming offset lag for a PubSub topic partition.
getOffsetLag(String, int) - Method in class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
Get consuming offset lag on a topic partition
getOffsetLagBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
getOffsetLagBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
getOffsetLagBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
getOffsetLagBasedOnMetrics(String, PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
getOffsetLagDeltaRelaxFactorForFastOnlineTransitionInRestart() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Gets the value of the 'offsetLagThresholdToGoOnline' field.
getOffsetLagThresholdToGoOnline() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
Gets the value of the 'offsetLagThresholdToGoOnline' field.
getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Gets the value of the 'offsetLagThresholdToGoOnline' field.
getOffsetRecord() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getOffsetRecord() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'offsetRecord' field.
getOffsetRecord(long) - Static method in class com.linkedin.venice.utils.TestUtils
 
getOffsetRecord(long, boolean) - Static method in class com.linkedin.venice.utils.TestUtils
 
getOffsetRecord(long, Optional<Long>) - Static method in class com.linkedin.venice.utils.TestUtils
 
getOffsetRecordArray() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'offsetRecordArray' field.
getOffsetRegressionDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getOffsets() - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
getOffsets(Map<String, Long>) - Static method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
 
getOffsetToOnlineLagThresholdPerPartition(Optional<HybridStoreConfig>, String, int) - Static method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getOldServingVersionTopic() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Gets the value of the 'oldServingVersionTopic' field.
getOngoingIncrementalPushStatusesKey(int) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
 
getOngoingIncrementalPushVersions(Admin) - Method in class com.linkedin.venice.controller.server.JobRoutes
 
getOngoingIncrementalPushVersions(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getOngoingIncrementalPushVersions(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Check if there are any ongoing incremental push for the given version topic.
getOngoingIncrementalPushVersions(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getOngoingIncrementalPushVersions(String, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
Get ongoing incremental push versions from the push status store
getOngoingIncrementalPushVersions(String, PushStatusStoreReader) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
 
getOngoingIncrementalPushVersions(String, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getOnlineFutureVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getOnlineRequestCount() - Method in class com.linkedin.alpini.router.api.Scatter
 
getOnlineRequests() - Method in class com.linkedin.alpini.router.api.Scatter
 
getOperation() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
Gets the value of the 'operation' field.
getOperation() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
getOperationResultFields() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
 
getOperationResultFields(List<ComputeOperation>, Schema) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
getOperations() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
 
getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
Gets the value of the 'operations' field.
getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
Gets the value of the 'operations' field.
getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
Gets the value of the 'operations' field.
getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
Gets the value of the 'operations' field.
getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
Gets the value of the 'operations' field.
getOperationType() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
Gets the value of the 'operationType' field.
getOperationType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
Gets the value of the 'operationType' field.
getOperator() - Method in enum com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
 
getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
 
getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CountOperator
 
getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.DotProductOperator
 
getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.HadamardProductOperator
 
getOperatorFieldName(ComputeOperation) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
 
getOptimizeDatabaseForBackupVersionNoReadThresholdMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getOptimizeDatabaseServiceScheduleIntervalSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getOptionalArgs() - Method in enum com.linkedin.venice.Command
 
getOptionalExtraDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
N.B.: Older versions of the controller did not support these details, so the optional can be empty.
getOptionalField(Map<String, String>, String) - Static method in class com.linkedin.venice.status.StatusMessage
 
getOptionalInt(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getOptionalParameterValue(Request, String) - Static method in class com.linkedin.venice.controller.server.AdminSparkServer
 
getOptionalParameterValue(Request, String, String) - Static method in class com.linkedin.venice.controller.server.AdminSparkServer
 
getOptionalParams() - Method in enum com.linkedin.venice.controllerapi.ControllerRoute
 
getOptionalStatusDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
N.B.: Older versions of the controller did not support these details, so the optional can be empty.
getOptionalStatusDetails() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getOptions() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getOrDefault(Object, V) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
getOriginalFuture() - Method in class com.linkedin.venice.utils.concurrent.ChainedCompletableFuture
 
getOriginalManager() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getOriginalRequestStartTs() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getOtherClusters() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Gets the value of the 'otherClusters' field.
getOutboundQueueSize() - Method in class com.linkedin.alpini.netty4.ssl.FusedSslHandler
The length of the outbound queue.
getOutboundQueueSizeLimit() - Method in class com.linkedin.alpini.netty4.ssl.FusedSslHandler
 
getOutput() - Method in class com.linkedin.alpini.io.ExternalCommand
 
getOutput() - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapperOutputReader
 
getOutputAvailable() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
getOutputAvailable() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
getOutputBuffer() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
getOutputBuffer() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
getOutputRecordsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getOutputRecordsCount() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getOutputRecordsCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getOutputRecordsCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getOutputStream() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
 
getOutstandingCount() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getOutstandingCount() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getOutstandingStartTimeAvg() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getOutstandingStartTimeAvg() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getOverallExecutionStatus() - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Check whether all the stream reprocessing jobs have succeeded; return false if any of them fail.
getOverallStatus() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'overallStatus' field.
getOwner() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
Gets the value of the 'owner' field.
getOwner() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Gets the value of the 'owner' field.
getOwner() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'owner' field.
getOwner() - Method in class com.linkedin.venice.controllerapi.NewStoreResponse
 
getOwner() - Method in class com.linkedin.venice.controllerapi.OwnerResponse
 
getOwner() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getOwner() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getOwner() - Method in interface com.linkedin.venice.meta.Store
 
getOwner() - Method in class com.linkedin.venice.meta.StoreInfo
Store Owner
getOwner() - Method in class com.linkedin.venice.meta.SystemStore
 
getOwner() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'owner' field.
getOwner() - Method in class com.linkedin.venice.meta.ZKStore
 
getOwner() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'owner' field.
getOwner() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
Returns the thread that currently owns the write lock, or null if not owned.
getOwners() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Gets the value of the 'owners' field.
getOwners() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Gets the value of the 'owners' field.
getOwners() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
getOwners() - Method in class com.linkedin.venice.persona.Persona
 
getOwnersAsList() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
getParallelBatchGetChunkSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getParameters() - Method in class com.linkedin.alpini.base.misc.QueryStringDecoder
Returns the decoded key-value parameter pairs of the URI.
getParams() - Method in enum com.linkedin.venice.controllerapi.ControllerRoute
 
getParams() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
getParams() - Method in class com.linkedin.venice.datarecovery.MonitorCommand
 
getParams() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
getParentControllerMaxErroredTopicNumToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getParentControllerMaxErroredTopicNumToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getParentControllerWaitingTimeForConsumptionMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getParentControllerWaitingTimeForConsumptionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getParentFabrics() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getParentFabrics() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getParentSystemStoreHeartbeatCheckWaitTimeSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getParentSystemStoreRepairCheckIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getParentSystemStoreRepairRetryCount() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getParentUrl() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
 
getParentUrl() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
 
getParserForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
getParserForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
getParticipant(String, String, String, int, String) - Static method in class com.linkedin.venice.utils.TestUtils
Deprecated.
TODO: migrate to use ServiceFactory for generating a participant
getParticipant(String, String, String, int, StateModelFactory<StateModel>, String) - Static method in class com.linkedin.venice.utils.TestUtils
 
getParticipantId() - Method in class com.linkedin.venice.routerapi.ReplicaState
 
getParticipantMessageConsumptionDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getParticipantStoreNameForCluster(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
getPartition() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
getPartition() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
getPartition() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getPartition() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getPartition() - Method in class com.linkedin.davinci.validation.PartitionTracker
 
getPartition() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getPartition() - Method in class com.linkedin.venice.listener.request.AdminRequest
 
getPartition() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
 
getPartition() - Method in class com.linkedin.venice.listener.request.TopicPartitionIngestionContextRequest
 
getPartition() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
uint32 partition = 1;
getPartition() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
uint32 partition = 1;
getPartition() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
uint32 partition = 1;
getPartition() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
 
getPartition() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getPartition() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
The partition the record was sent to
getPartition() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
getPartition() - Method in class com.linkedin.venice.routerapi.ReplicaState
 
getPartition(byte[]) - Method in class com.linkedin.davinci.VersionBackend
 
getPartition(int) - Method in class com.linkedin.venice.meta.PartitionAssignment
 
getPartition(Object) - Method in class com.linkedin.venice.hadoop.spark.datawriter.partition.VeniceSparkPartitioner
 
getPartition(String, int) - Method in class com.linkedin.venice.helix.ResourceAssignment
 
getPartition(BytesWritable, int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputMRPartitioner
 
getPartition(BytesWritable, int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
 
getPartition(BytesWritable, BytesWritable, int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
 
getPartitionAssignment(String) - Method in class com.linkedin.venice.helix.ResourceAssignment
TODO: Rename this "getPartitionAssignmentOrThrow", and create an equivalent which returns null when absent.
getPartitionAssignments(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
getPartitionAssignments(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Query all partitions allocations that belong to given kafka topic.
getPartitionConsumptionState() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
getPartitionConsumptionState(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getPartitionConsumptionStates() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Gets the value of the 'partitionConsumptionStates' field.
getPartitionCount() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
getPartitionCount() - Method in interface com.linkedin.davinci.client.DaVinciClient
Get partition count of a store.
getPartitionCount() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
getPartitionCount() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
 
getPartitionCount() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
getPartitionCount() - Method in class com.linkedin.davinci.VersionBackend
 
getPartitionCount() - Method in class com.linkedin.venice.controllerapi.PartitionResponse
 
getPartitionCount() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getPartitionCount() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
getPartitionCount() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getPartitionCount() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getPartitionCount() - Method in interface com.linkedin.venice.meta.Store
 
getPartitionCount() - Method in class com.linkedin.venice.meta.StoreInfo
The number of partitions for this store
getPartitionCount() - Method in class com.linkedin.venice.meta.SystemStore
 
getPartitionCount() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'partitionCount' field.
getPartitionCount() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'partitionCount' field.
getPartitionCount() - Method in interface com.linkedin.venice.meta.Version
 
getPartitionCount() - Method in class com.linkedin.venice.meta.VersionImpl
 
getPartitionCount() - Method in class com.linkedin.venice.meta.ZKStore
 
getPartitionCount() - Method in class com.linkedin.venice.metadata.response.VersionProperties
Gets the value of the 'partitionCount' field.
getPartitionCount() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'partitionCount' field.
getPartitionCount() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'partitionCount' field.
getPartitionCount() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'partitionCount' field.
getPartitionCount() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getPartitionCount(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Get partition count for a given topic.
getPartitionCount(String) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
 
getPartitionCountRoundUpSize() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getPartitionDbName(String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
getPartitionDetails() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getPartitioner() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getPartitionerClass() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
Gets the value of the 'partitionerClass' field.
getPartitionerClass() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getPartitionerClass() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getPartitionerClass() - Method in interface com.linkedin.venice.meta.PartitionerConfig
 
getPartitionerClass() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
getPartitionerClass() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
Gets the value of the 'partitionerClass' field.
getPartitionerClass() - Method in class com.linkedin.venice.metadata.response.VersionProperties
Gets the value of the 'partitionerClass' field.
getPartitionerClass() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
Gets the value of the 'partitionerClass' field.
getPartitionerConfig() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'partitionerConfig' field.
getPartitionerConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getPartitionerConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getPartitionerConfig() - Method in interface com.linkedin.venice.meta.Store
 
getPartitionerConfig() - Method in class com.linkedin.venice.meta.StoreInfo
 
getPartitionerConfig() - Method in class com.linkedin.venice.meta.SystemStore
 
getPartitionerConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'partitionerConfig' field.
getPartitionerConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'partitionerConfig' field.
getPartitionerConfig() - Method in interface com.linkedin.venice.meta.Version
 
getPartitionerConfig() - Method in class com.linkedin.venice.meta.VersionImpl
 
getPartitionerConfig() - Method in class com.linkedin.venice.meta.ZKStore
 
getPartitionerConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'partitionerConfig' field.
getPartitionerConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'partitionerConfig' field.
getPartitionerParams() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
Gets the value of the 'partitionerParams' field.
getPartitionerParams() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getPartitionerParams() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getPartitionerParams() - Method in interface com.linkedin.venice.meta.PartitionerConfig
 
getPartitionerParams() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
getPartitionerParams() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
Gets the value of the 'partitionerParams' field.
getPartitionerParams() - Method in class com.linkedin.venice.metadata.response.VersionProperties
Gets the value of the 'partitionerParams' field.
getPartitionerParams() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
Gets the value of the 'partitionerParams' field.
getPartitionGracefulDropDelaySeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getPartitionId() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
returns the id of this partition
getPartitionId() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
getPartitionId() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'partitionId' field.
getPartitionId() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Gets the value of the 'partitionId' field.
getPartitionId() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext.KeyInfo
 
getPartitionId() - Method in class com.linkedin.venice.helix.Replica
 
getPartitionId() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Gets the value of the 'partitionId' field.
getPartitionId() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
Gets the value of the 'partitionId' field.
getPartitionId() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'partitionId' field.
getPartitionId() - Method in class com.linkedin.venice.meta.PartitionDetail
 
getPartitionId() - Method in class com.linkedin.venice.meta.UncompletedPartition
 
getPartitionId() - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
getPartitionId() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Gets the value of the 'partitionId' field.
getPartitionId() - Method in class com.linkedin.venice.router.api.RouterKey
 
getPartitionId() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.ConstantVenicePartitioner
 
getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.DefaultVenicePartitioner
 
getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.InvalidKeySchemaPartitioner
 
getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.UserPartitionAwarePartitioner
 
getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.VenicePartitioner
A function that returns the partitionId based on the key and partition count.
getPartitionId(byte[], int) - Method in class com.linkedin.venice.unit.kafka.SimplePartitioner
 
getPartitionId(byte[], int, int, int) - Method in class com.linkedin.venice.partitioner.DefaultVenicePartitioner
 
getPartitionId(byte[], int, int, int) - Method in class com.linkedin.venice.partitioner.VenicePartitioner
Implementors of this class can optionally provide an implementation of this function, which would result in eliminating an instantiation of ByteBuffer in the case where the provided offset and length do not map to the boundaries of the byte[].
getPartitionId(int, byte[]) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
getPartitionId(int, byte[]) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getPartitionId(int, ByteBuffer) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getPartitionId(int, ByteBuffer) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getPartitionId(int, ByteBuffer) - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getPartitionId(String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.ConstantVenicePartitioner
 
getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.DefaultVenicePartitioner
 
getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.InvalidKeySchemaPartitioner
 
getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.UserPartitionAwarePartitioner
 
getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.VenicePartitioner
 
getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.unit.kafka.SimplePartitioner
 
getPartitionIdFromServerIncrementalPushKey(PushStatusKey) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
 
getPartitionIds() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Get all Partition Ids which are assigned to the current Node.
getPartitionIngestionStatus(int) - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
getPartitionIngestionStatusSet() - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
getPartitionKey() - Method in interface com.linkedin.alpini.router.api.ResourcePath
 
getPartitionKeys() - Method in interface com.linkedin.alpini.router.api.ResourcePath
 
getPartitionKeys() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
 
getPartitionKeys() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getPartitionName(String, int) - Static method in class com.linkedin.venice.utils.HelixUtils
 
getPartitionNameFromVeniceClusterName(String) - Static method in class com.linkedin.venice.controller.VeniceControllerStateModel
Get the controller partition name.
getPartitionNamesToQuery() - Method in class com.linkedin.alpini.router.api.BroadcastScatterGatherRequest
For table level query requests, return the list of partitions that should be queried for this request.
getPartitionNamesToQuery() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
Only used by broadcast queries.
getPartitionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
Gets the value of the 'partitionNum' field.
getPartitionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'partitionNum' field.
getPartitionNumber() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopicPartition
 
getPartitionNumber() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
 
getPartitionOffset(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Retrieve the offset associated with the partitionId from the metadata partition.
getPartitionOffsetLagBasedOnMetrics(String, PubSubTopic, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getPartitionOffsetRecords(String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
This method should only be called when the forked ingestion process is handing over ingestion task to main process.
getPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
getPartitionQuotaInBytes() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
getPartitions() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getPartitionSize() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Get the partition database size in bytes
getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getPartitionSizeInBytes(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getPartitionStateSerializer() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getPartitionStateSerializer() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getPartitionStatus(int) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getPartitionStatus(PartitionStatus, int, Map<Instance, HelixState>, DisableReplicaCallback) - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
 
getPartitionStatus(String, int) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
Get one partition status ZNode from ZK by given topic and partition.
getPartitionStatus(String, int, int, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
getPartitionStatus(String, int, int, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
getPartitionStatuses() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getPartitionStatuses(String, int) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
Get all partition status ZNodes under offline push of given topic from ZK.
getPartitionStatuses(String, int, String, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
Return statuses of all replicas belonging to partitions with partitionIds in the range [0 (inclusive), numberOfPartitions (exclusive)) {partitionId: {instance:status, instance:status,...},...}
getPartitionStatuses(String, int, String, int, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
getPartitionStatuses(String, int, String, Set<Integer>, Optional<Integer>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
Return statuses of all replicas belonging to partitions mentioned in partitionIds.
getPartitionWriterCloseCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getPartitionWriterCloseCount() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getPartitionWriterCloseCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getPartsInvokeDelayLatency() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getPassword(Credentials, Text) - Method in class com.linkedin.venice.hadoop.ssl.TempFileSSLConfigurator
 
getPath() - Method in class com.linkedin.alpini.base.misc.Metrics
 
getPath() - Method in class com.linkedin.alpini.base.misc.QueryStringDecoder
Returns the decoded path string of the URI.
getPath() - Method in class com.linkedin.alpini.router.api.Scatter
 
getPath() - Method in enum com.linkedin.venice.controllerapi.ControllerRoute
 
getPathFormat() - Method in enum com.linkedin.venice.controllerapi.routes.V1Delete
 
getPathFormat() - Method in enum com.linkedin.venice.controllerapi.routes.V1Get
 
getPathFormat() - Method in enum com.linkedin.venice.controllerapi.routes.V1Post
 
getPathFormat() - Method in enum com.linkedin.venice.controllerapi.routes.V1Put
 
getPathFormat() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
The actual format string with "%s" in place of parameters that will be substituted
getPathForResource(String) - Static method in class com.linkedin.venice.utils.SslUtils
This function should be used in test cases only.
getPathParams() - Method in enum com.linkedin.venice.controllerapi.routes.V1Delete
 
getPathParams() - Method in enum com.linkedin.venice.controllerapi.routes.V1Get
 
getPathParams() - Method in enum com.linkedin.venice.controllerapi.routes.V1Post
 
getPathParams() - Method in enum com.linkedin.venice.controllerapi.routes.V1Put
 
getPathParams() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
 
getPathParamsList() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
 
getPathParser() - Method in class com.linkedin.alpini.router.api.Scatter
 
getPathWithParameters(String[]) - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
Similar to V1Route.getPathWithParameters(Map) but takes an ordered list of parameters for substitution.
getPathWithParameters(Map<String, String>) - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
Generate path with specified parameters substituted into the path.
getPayload() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Gets the value of the 'payload' field.
getPayloadChunks() - Method in class com.linkedin.venice.writer.ChunkedPayloadAndManifest
 
getPayloadSize() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
getPayloadSize() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getPayloadSize() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
getPayloadUnion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
Gets the value of the 'payloadUnion' field.
getPayloadUnion() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Gets the value of the 'payloadUnion' field.
getPCtrlCliWithoutCluster() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
 
getPCtrlCliWithoutCluster() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
 
getPCtrlCliWithoutCluster() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getPendingAcquireCount() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolWithStats
 
getPendingAcquireCount() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
getPendingAcquireCount() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
getPendingAcquireCount() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getPendingHandshakes() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
Returns the number of handshakes which are currently blocked awaiting a permit.
getPendingRequestCount(String) - Method in class com.linkedin.venice.router.stats.RouteHttpRequestStats
 
getPendingRequestCount(String) - Method in class com.linkedin.venice.stats.HttpConnectionPoolStats
 
getPendingRequestCounter(String) - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
 
getPendingRequestThrottler() - Method in class com.linkedin.venice.router.api.VeniceDispatcher
For TEST ONLY
getPercentileStat(String) - Static method in class com.linkedin.venice.stats.TehutiUtils
Generate a histogram stat that emits P50, P95, and P99 values.
getPercentileStat(String, int, double) - Static method in class com.linkedin.venice.stats.TehutiUtils
Generate a histogram stat that emits P50, P95, and P99 values.
getPercentileStat(String, int, double, double...) - Static method in class com.linkedin.venice.stats.TehutiUtils
 
getPercentileStat(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
TODO: need to investigate why percentiles with big values (> 10^6) won't show in InGraph.
getPercentileStatForNetworkLatency(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
Generate a histogram stat that emits P50, P77, P90, P95, P99 and P99.9 values.
getPercentileStatWithAvgAndMax(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
 
getPermission() - Method in class com.linkedin.venice.authorization.AceEntry
 
getPerNodeClientThreadCount() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
 
getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngine
 
getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
getPersistedStoreNames() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
getPersistedStoreNames() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
getPersistedStoreNames() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getPersistedStoreNames() - Method in class com.linkedin.davinci.store.StorageEngineFactory
Retrieve all the stores persisted previously
getPersistedToDBFuture() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getPersistenceType() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getPersistenceType() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
getPersistenceType() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
getPersistenceType() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getPersistenceType() - Method in class com.linkedin.davinci.store.StorageEngineFactory
Return the persistence type current factory supports.
getPersistenceType() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getPersistenceType() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getPersistenceType() - Method in interface com.linkedin.venice.meta.Store
 
getPersistenceType() - Method in class com.linkedin.venice.meta.SystemStore
 
getPersistenceType() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'persistenceType' field.
getPersistenceType() - Method in class com.linkedin.venice.meta.ZKStore
 
getPersistenceType() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'persistenceType' field.
getPersistenceTypeFromInt(int) - Static method in enum com.linkedin.venice.meta.PersistenceType
 
getPersistStorageEngineConfig() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
getPersona(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
Returns a persona with the given name within the cluster that the repository is located.
getPersonaAssociatedWithStore(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
 
getPersonaAssociatedWithStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getPersonaAssociatedWithStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getPersonaAssociatedWithStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getPersonaContainingStore(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
getPersonaFromZk(String) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
 
getPerStoreRouterQuotaBuffer() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getPid() - Static method in enum com.linkedin.alpini.base.misc.ProcessUtil
 
getPid() - Static method in class com.linkedin.venice.utils.Utils
Note: this may fail in some JVM implementations.
getPipelineSupplier() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getPlatform() - Static method in class com.linkedin.alpini.jna.ThreadUtils
 
getPools() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
getPoolSize() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the pool size at the time of the call to getStats().
getPoolStats() - Method in interface com.linkedin.alpini.base.pool.AsyncPool
 
getPoolStats() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
getPort() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
 
getPort() - Method in class com.linkedin.venice.meta.Instance
 
getPort() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getPos() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
getPosition() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
getPositionFromWireFormat(byte[]) - Static method in interface com.linkedin.venice.pubsub.api.PubSubPosition
 
getPositionFromWireFormat(byte[]) - Static method in class com.linkedin.venice.pubsub.PubSubPositionFactory
 
getPositionFromWireFormat(PubSubPositionWireFormat) - Static method in interface com.linkedin.venice.pubsub.api.PubSubPosition
 
getPositionFromWireFormat(PubSubPositionWireFormat) - Static method in class com.linkedin.venice.pubsub.PubSubPositionFactory
 
getPositionWireFormat() - Method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
Position wrapper is used to wrap the position type and the position value.
getPositionWireFormat() - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
Position wrapper is used to wrap the position type and the position value.
getPotentiallyLossyLeaderOffsetRewindCount() - Method in class com.linkedin.davinci.stats.DIVStats
 
getPreferredSchemaFilter() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getPrefix() - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
getPreviousStatuses() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'previousStatuses' field.
getPreviousValue() - Method in class com.linkedin.davinci.consumer.ChangeEvent
 
getPreviousValue() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Gets the value of the 'previousValue' field.
getPrincipal() - Method in class com.linkedin.venice.authorization.AceEntry
 
getPrincipalId(X509Certificate) - Method in interface com.linkedin.venice.acl.AccessController
Get principal Id from client certificate.
getPrincipalId(Request) - Method in class com.linkedin.venice.controller.server.AbstractRoute
Get principal Id from request.
getProcessedRecordSizeSinceLastSync() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getProcessedRecordSizeSinceLastSync() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Gets the value of the 'processedRecordSizeSinceLastSync' field.
getProducedOffset() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getProducedTimestampMs() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getProducer(String, String, boolean, String, Config) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
Samza table writer would directly call this function to create venice system producer instead of calling the general VeniceSystemFactory.getProducer(String, Config, MetricsRegistry) function.
getProducer(String, Config, MetricsRegistry) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
The core function of a SystemFactory; most Samza users would specify VeniceSystemFactory in the job config and Samza would invoke SystemFactory.getProducer(String, Config, MetricsRegistry) to create producers.
getProducerAdapterFactory() - Method in class com.linkedin.venice.pubsub.PubSubClientsFactory
 
getProducerCallBackLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getProducerConfigs() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'producerConfigs' field.
getProduceResult() - Method in class com.linkedin.venice.pubsub.adapter.PubSubProducerCallbackSimpleImpl
 
getProducerGUID() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Gets the value of the 'producerGUID' field.
getProducerGUID() - Method in class com.linkedin.venice.storage.protocol.ChunkId
Gets the value of the 'producerGUID' field.
getProducerGUID() - Method in class com.linkedin.venice.writer.VeniceWriter
 
getProducerLocalBrokerLatencySensor() - Method in class com.linkedin.davinci.stats.DIVStats
 
getProducerMetadata() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Gets the value of the 'producerMetadata' field.
getProducerPartitionState(GUID) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getProducerPartitionStateMap() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getProducerProperties() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
getProducerSourceBrokerLatencySensor() - Method in class com.linkedin.davinci.stats.DIVStats
 
getProducerStates() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'producerStates' field.
getProducerTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
 
getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Gets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
Gets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Gets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
getProducerTimestampOfLastDataMessageCached(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getProducerTimestampOfLastDataMessageWithRetries(PubSubTopicPartition, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getProduceToTopicFunction(byte[], ByteBuffer, ByteBuffer, ChunkedValueManifest, ChunkedValueManifest, int, boolean) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
getProgress() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
getProgress() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getProgress() - Method in interface com.linkedin.venice.hadoop.task.TaskTracker
Get the progress of the task.
getProgress() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getProperties() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getPropertiesCopy() - Method in class com.linkedin.venice.utils.VeniceProperties
 
getPropertiesForControllerConfig() - Static method in class com.linkedin.venice.utils.TestUtils
 
getPropertiesList() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getProperty(List<PropertyKey>) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
N.B.: The behavior of this function is different from that of HelixDataAccessor, which would swallow exceptions and return an empty collection.
getProperty(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
getPropertyDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
 
getPropertyDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
 
getPropertyStat(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
getPropertyStats(List<PropertyKey>) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
getProps() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getProps(JobConf) - Static method in class com.linkedin.venice.hadoop.utils.HadoopUtils
 
getProtocolVersion() - Method in enum com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
 
getPubSubAdminAdapterFactory() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getPubsubBrokerAddress(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
getPubSubClientsFactory() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getPubSubClientsFactory() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getPubSubClientsFactory() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getPubSubClientsFactory() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getPubSubClusterAddress() - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getPubSubConsumer() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
getPubSubConsumerAdapterFactory() - Method in interface com.linkedin.venice.controller.Admin
 
getPubSubConsumerAdapterFactory() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getPubSubConsumerAdapterFactory() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getPubSubConsumerAdapterFactory() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getPubSubConsumerPollRetryBackoffMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getPubSubConsumerPollRetryTimes() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getPubSubConsumerProperties(String, Properties) - Static method in class com.linkedin.venice.DumpAdminMessages
 
getPubSubMessageHeaders() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getPubSubMessageHeaders() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
getPubSubMessageTime() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
getPubSubMessageTime() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getPubSubMessageTime() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
getPubSubOperationTimeoutMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getPubSubProperties(String) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getPubSubPropertiesSupplier() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getPubSubSSLProperties(String) - Method in interface com.linkedin.venice.controller.Admin
 
getPubSubSSLProperties(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getPubSubSSLProperties(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getPubSubTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopicPartition
 
getPubSubTopic() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
 
getPubSubTopicPartition() - Method in class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
 
getPubSubTopicRepository() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getPubSubTopicRepository() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getPubSubTopicType() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
getPubSubTopicType() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
 
getPubSubTopicType(String) - Static method in enum com.linkedin.venice.pubsub.api.PubSubTopicType
 
getPushEndDateTime() - Method in class com.linkedin.venice.meta.ReplicaDetail
 
getPushEndTimestamp() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getPushId() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'pushId' field.
getPushJobConfigs() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'pushJobConfigs' field.
getPushJobDetails(PushJobStatusRecordKey) - Method in interface com.linkedin.venice.controller.Admin
 
getPushJobDetails(PushJobStatusRecordKey) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getPushJobDetails(PushJobStatusRecordKey) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getPushJobDetailsStoreName() - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
getPushJobId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'pushJobId' field.
getPushJobId() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getPushJobId() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'pushJobId' field.
getPushJobId() - Method in interface com.linkedin.venice.meta.Version
 
getPushJobId() - Method in class com.linkedin.venice.meta.VersionImpl
 
getPushJobId() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'pushJobId' field.
getPushJobLatestCheckpoint() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'pushJobLatestCheckpoint' field.
getPushJobSetting() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
getPushJobSetting() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
getPushJobSetting() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
getPushJobSetting() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
getPushJobStatusStoreClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getPushJobStatusStoreClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getPushKey(int) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
 
getPushKey(int, int, Optional<String>) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
 
getPushKey(int, int, Optional<String>, Optional<String>) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
 
getPushMonitor() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getPushMonitorType() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getPushProperties() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getPushSSLAllowlist() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getPushStartDateTime() - Method in class com.linkedin.venice.meta.ReplicaDetail
 
getPushStartTimestamp() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getPushStatus(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getPushStatusAndDetails(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getPushStatusAndDetails(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
 
getPushStatusAndDetails(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getPushStatusDecider() - Method in enum com.linkedin.venice.meta.OfflinePushStrategy
 
getPushStatusNotifierList() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getPushStatusStoreHeartbeatExpirationTimeInSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getPushStatusStoreReader() - Method in interface com.linkedin.venice.controller.Admin
 
getPushStatusStoreReader() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getPushStatusStoreReader() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getPushStatusStoreWriter() - Method in interface com.linkedin.venice.controller.Admin
 
getPushStatusStoreWriter() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getPushStatusStoreWriter() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'pushStreamSourceAddress' field.
getPushStreamSourceAddress() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'pushStreamSourceAddress' field.
getPushStreamSourceAddress() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getPushStreamSourceAddress() - Method in interface com.linkedin.venice.meta.Store
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.StoreInfo
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.SystemStore
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'pushStreamSourceAddress' field.
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'pushStreamSourceAddress' field.
getPushStreamSourceAddress() - Method in interface com.linkedin.venice.meta.Version
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.VersionImpl
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.ZKStore
 
getPushStreamSourceAddress() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'pushStreamSourceAddress' field.
getPushStreamSourceAddress() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'pushStreamSourceAddress' field.
getPushType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'pushType' field.
getPushType() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getPushType() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'pushType' field.
getPushType() - Method in interface com.linkedin.venice.meta.Version
 
getPushType() - Method in class com.linkedin.venice.meta.VersionImpl
 
getPushType() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'pushType' field.
getPutOnlyPartLength() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
getPutValue() - Method in class com.linkedin.venice.kafka.protocol.Put
Gets the value of the 'putValue' field.
getQOS() - Method in class com.linkedin.alpini.base.queuing.QOSBasedRequestRunnable
 
getQOS(T) - Method in class com.linkedin.alpini.base.queuing.AbstractQOSBasedQueue
 
getQosPolicy() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
getQosPolicy() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.StaticConfig
 
getQOSPolicy(QOSPolicy.StaticConfig) - Static method in enum com.linkedin.alpini.base.queuing.QOSPolicy
 
getQuantile() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantile
 
getQuery() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
getQueryParamsToDiscoverCluster(String) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
 
getQueue() - Method in class com.linkedin.alpini.base.misc.RetryCountSlidingWindow
Return a ThreadLocal Queue for I/O workers to keep counting retriy request count and total count.
getQueue() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Returns the task queue used by this executor.
getQueuedReaderThreads() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
Returns a collection containing threads that may be waiting to acquire the read lock.
getQueuedThreads() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
Returns a collection containing threads that may be waiting to acquire either the read or write lock.
getQueuedWriterThreads() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
Returns a collection containing threads that may be waiting to acquire the write lock.
getQueueName(T) - Method in class com.linkedin.alpini.base.queuing.AbstractQOSBasedQueue
 
getQueuePollOrder() - Method in class com.linkedin.alpini.base.queuing.AbstractQOS
Computes and returns the order in which the Queues are to be polled/peeked for this request
getQuota() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
getQuotaEnforcer() - Method in class com.linkedin.venice.listener.HttpChannelInitializer
 
getQuotaNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Gets the value of the 'quotaNumber' field.
getQuotaNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Gets the value of the 'quotaNumber' field.
getQuotaNumber() - Method in class com.linkedin.venice.persona.Persona
 
getQuotaStatus() - Method in class com.linkedin.venice.routerapi.HybridStoreQuotaStatusResponse
 
getR2Client() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getR2Client() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig
 
getR2Client() - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
getR2Client(ClientTestUtils.FastClientHTTPVariant) - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
getR2Client(SSLContext) - Static method in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
 
getR2Client(SSLContext, int) - Static method in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
 
getR2Client(SSLContext, int, long) - Static method in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
 
getRandomBytes(int) - Static method in class com.linkedin.venice.utils.RandomGenUtils
Generate an array of random bytes
getRandomFloat() - Static method in class com.linkedin.venice.utils.RandomGenUtils
 
getRandomIntInRange(int, int) - Static method in class com.linkedin.venice.utils.RandomGenUtils
 
getRandomIntWithin(int) - Static method in class com.linkedin.venice.utils.RandomGenUtils
Return a random integer between 0 and limit (exclusive)
getRandomStore() - Static method in class com.linkedin.venice.utils.TestUtils
 
getRate() - Method in class com.linkedin.venice.stats.LongAdderRateGauge
 
getRateConfig() - Method in class com.linkedin.venice.throttle.EventThrottler
 
getRateLimiter() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getRaw(String) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
 
getRaw(String) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
getRaw(String, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getRaw(String, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
getRaw(String, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
 
getRawBytes() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
Gets the value of the 'rawBytes' field.
getRawBytes() - Method in class org.apache.avro.io.OptimizedBinaryDecoder
 
getRawKeyBytes() - Method in class com.linkedin.venice.chunking.RawKeyBytesAndChunkedKeySuffix
 
getRawPath() - Method in enum com.linkedin.venice.controllerapi.routes.V1Delete
 
getRawPath() - Method in enum com.linkedin.venice.controllerapi.routes.V1Get
 
getRawPath() - Method in enum com.linkedin.venice.controllerapi.routes.V1Post
 
getRawPath() - Method in enum com.linkedin.venice.controllerapi.routes.V1Put
 
getRawPath() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
Path formatted with colons prefixing each path parameter for use in defining the path in SparkJava ex /user/:id
getRawValue() - Method in class com.linkedin.alpini.base.misc.TimeValue
Get the raw value for this TimeValue using the TimeUnit used during creation
getRawValue(TimeUnit) - Method in class com.linkedin.alpini.base.misc.TimeValue
Get the raw value for this TimeValue using the TimeUnit supplied.
getRcu(RouterRequest) - Static method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
Initially, this is the key count.
getRCU() - Method in class com.linkedin.davinci.listener.response.ReadResponse
Get the read compute unit (RCU) for this response's request
getReadCapacity() - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
getReadCapacity() - Method in interface com.linkedin.venice.router.throttle.RouterThrottler
 
getReadComputationEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'readComputationEnabled' field.
getReadComputationEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getReadComputationEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'readComputationEnabled' field.
getReadComputationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'readComputationEnabled' field.
getReadComputeDeserializationLatency() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getReadComputeLatency() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getReadComputeOutputSize() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getReadComputeSerializationLatency() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getReader() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
Gets the reader schema that was validated.
getReaderSchema() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getReaderSchema() - Method in class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
 
getReadOnlyZKSharedSchemaRepository() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
getReadOnlyZKSharedSchemaRepository() - Method in interface com.linkedin.venice.controller.Admin
Return a shared read only schema repository for zk shared stores.
getReadOnlyZKSharedSchemaRepository() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getReadOnlyZKSharedSchemaRepository() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getReadOnlyZKSharedSystemStoreRepository() - Method in interface com.linkedin.venice.controller.Admin
Return a shared read only store repository for zk shared stores.
getReadOnlyZKSharedSystemStoreRepository() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getReadOnlyZKSharedSystemStoreRepository() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getReadOptionsForMultiGet() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getReadQuotaInCU() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'readQuotaInCU' field.
getReadQuotaInCU() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getReadQuotaInCU() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getReadQuotaInCU() - Method in interface com.linkedin.venice.meta.Store
 
getReadQuotaInCU() - Method in class com.linkedin.venice.meta.StoreInfo
 
getReadQuotaInCU() - Method in class com.linkedin.venice.meta.SystemStore
 
getReadQuotaInCU() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'readQuotaInCU' field.
getReadQuotaInCU() - Method in class com.linkedin.venice.meta.ZKStore
 
getReadQuotaInCU() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'readQuotaInCU' field.
getReadQuotaThrottlingLeaseTimeoutMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getReadResponse() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
getReadStrategy() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getReadStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getReadStrategy() - Method in interface com.linkedin.venice.meta.Store
 
getReadStrategy() - Method in class com.linkedin.venice.meta.SystemStore
 
getReadStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'readStrategy' field.
getReadStrategy() - Method in class com.linkedin.venice.meta.ZKStore
 
getReadStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'readStrategy' field.
getReadStrategyFromInt(int) - Static method in enum com.linkedin.venice.meta.ReadStrategy
 
getReadWriteRegularStoreSchemaRepository() - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getReadWriteStoreRepository() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getReadyToServeInstances() - Method in class com.linkedin.venice.meta.Partition
 
getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
Get ready to serve instances from local memory.
getReadyToServeInstances(PartitionAssignment, int) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
Look for ready to serve instances on the given partition assignment.
getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.pushmonitor.PartitionStatusBasedPushMonitor
 
getReadyToServeInstances(PartitionAssignment, int) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
 
getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getReadyToServeInstances(PartitionStatus, PartitionAssignment, int) - Static method in class com.linkedin.venice.pushmonitor.PushStatusDecider
 
getReadyToServeInstances(String, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
Get instances from local memory.
getReadyToServeInstances(String, int) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
Query instances that belong to given kafka topic and partition.
getReadyToServeInstances(Map<CharSequence, StoreReplicaStatus>) - Static method in class com.linkedin.venice.pushmonitor.PushStatusDecider
Replicas will be considered ready to serve if their status is ExecutionStatus.COMPLETED.
getReadyToServeWithRTLag() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getRealTimeDataSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getRealTimeDataSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getRealTimeTopic(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getRealTimeTopic(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Get the real time topic name for a given store.
getRealTimeTopic(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getRealTimeTopicSwitcher() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getReason() - Method in class com.linkedin.venice.controllerapi.ReadyForDataRecoveryResponse
 
getReasonPhrase(HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
getReasonPhrase(HttpResponseStatus) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
getRecordCount() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getRecordCount() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
 
getRecordCount() - Method in class com.linkedin.venice.listener.response.StorageResponseObject
 
getRecordDatum(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
 
getRecordDatum(AvroWrapper<IndexedRecord>, NullWritable) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroRecordReader
 
getRecordNumInAllSSTFiles() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
 
getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.map.VeniceAvroMapper
 
getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.map.VeniceVsonMapper
 
getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.spark.datawriter.recordprocessor.SparkInputRecordProcessor
 
getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
A method for child classes to setup AbstractInputRecordProcessor.veniceRecordReader.
getRecordReader(InputSplit, JobConf, Reporter) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter) - Method in class com.linkedin.venice.hadoop.VeniceFileInputFormat
 
getRecordReader(InputSplit, JobConf, Reporter, PubSubConsumerAdapter) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
 
getRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getRecordTooLargeFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getRecordTooLargeFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getRecordTooLargeFailureCount() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getRecordTooLargeFailureCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getRecordTooLargeFailureCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getRecordTooLargeFailureCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getRecordTransformer(Integer) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
getRecordWithFloatArray(Schema, int, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictOutputFormat
Modify the output file name to be the MR job id to keep it unique.
getRecoveryStores() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient.DataRecoveryParams
 
getRedirectErrorStream() - Method in class com.linkedin.alpini.io.ExternalCommand
 
getReducerClosedCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getRedundantExceptionFilter() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getRedundantExceptionFilter() - Static method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
getReferenceCount() - Method in class com.linkedin.venice.utils.ReferenceCounted
 
getReferenceCount(String) - Method in class com.linkedin.venice.utils.SharedObjectFactory
Return the current reference count of the object identified by the {@param identifier}.
getRefreshAttemptsForZkReconnect() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getRefreshAttemptsForZkReconnect() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getRefreshAttemptsForZkReconnect() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRefreshIntervalForZkReconnectInMs() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getRefreshIntervalForZkReconnectInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getRefreshIntervalForZkReconnectInMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRefreshIntervalInSeconds() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getRegionHybridAvgConsumedOffset(int) - Method in class com.linkedin.davinci.stats.IngestionStats
 
getRegionHybridBytesConsumed(int) - Method in class com.linkedin.davinci.stats.IngestionStats
 
getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.stats.IngestionStats
 
getRegionHybridRecordsConsumed(int) - Method in class com.linkedin.davinci.stats.IngestionStats
 
getRegionName() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getRegionName() - Method in interface com.linkedin.venice.controller.Admin
Return the region name of this Admin
getRegionName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getRegionName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getRegionName() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getRegionName() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getRegionName() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getRegionNames() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getRegionPushDetails() - Method in class com.linkedin.venice.controllerapi.RegionPushDetailsResponse
 
getRegionPushDetails() - Method in class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
 
getRegionPushDetails(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getRegionPushDetails(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getRegionPushDetails(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
getRegionPushDetails(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getRegionPushDetails(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Gets the value of the 'regionsFilter' field.
getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Gets the value of the 'regionsFilter' field.
getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Gets the value of the 'regionsFilter' field.
getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
Gets the value of the 'regionsFilter' field.
getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
Gets the value of the 'regionsFilter' field.
getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'regionsFilter' field.
getRegionsFilter() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getRegionSpecificMetricPrefix(String, String) - Static method in class com.linkedin.venice.utils.RegionUtils
 
getRegionsWithStaleData() - Method in class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
 
getRegularVersionETLEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
Gets the value of the 'regularVersionETLEnabled' field.
getRegularVersionETLEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getRegularVersionETLEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
Gets the value of the 'regularVersionETLEnabled' field.
getRegularVersionETLEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Gets the value of the 'regularVersionETLEnabled' field.
getRemoteIngestionRepairService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getRemoteIngestionRepairSleepInterval() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getRemoveOnCancelPolicy() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Gets the policy on whether cancelled tasks should be immediately removed from the work queue at time of cancellation.
getReplicaCurrentStatus(List<StatusSnapshot>) - Static method in class com.linkedin.venice.pushmonitor.PushStatusDecider
The helper function is used by both controller and router (leader/follower stores); please be cautious when modifying it because it would affect both components.
getReplicaDetails() - Method in class com.linkedin.venice.meta.PartitionDetail
 
getReplicaHistoricStatusList(String) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
getReplicaId(String, int, String) - Static method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
getReplicas() - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
 
getReplicas() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
getReplicas(int, int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getReplicas(int, int) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getReplicas(int, int) - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getReplicas(long, int, int, int) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
This function is expected to return fully qualified URI, such as: "https://fake.host:8888".
getReplicas(long, int, int, int, Set<String>) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
getReplicas(long, int, int, int, Set<String>) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getReplicas(long, List<String>, int) - Method in class com.linkedin.venice.fastclient.meta.AbstractClientRoutingStrategy
 
getReplicas(long, List<String>, int) - Method in interface com.linkedin.venice.fastclient.meta.ClientRoutingStrategy
 
getReplicas(long, List<String>, int) - Method in class com.linkedin.venice.fastclient.meta.HelixScatterGatherRoutingStrategy
 
getReplicas(long, List<String>, int) - Method in class com.linkedin.venice.fastclient.meta.LeastLoadedClientRoutingStrategy
 
getReplicas(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getReplicas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getReplicas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getReplicasForInstance(RoutingDataRepository, String) - Static method in class com.linkedin.venice.utils.Utils
 
getReplicasOfStorageNode(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getReplicasOfStorageNode(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getReplicasOfStorageNode(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getReplicaStates() - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
 
getReplicaStates(String, int) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
 
getReplicaStatus(HelixPartitionState, String, String) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
 
getReplicaStatus(String) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
getReplicaStatus(String, int) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
 
getReplicaStatuses() - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
getReplicateAllConfigs() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'replicateAllConfigs' field.
getReplicateAllConfigs() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getReplicationCheckpointVector() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Gets the value of the 'replicationCheckpointVector' field.
getReplicationFactor() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'replicationFactor' field.
getReplicationFactor() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getReplicationFactor() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getReplicationFactor() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getReplicationFactor() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getReplicationFactor() - Method in interface com.linkedin.venice.meta.Store
 
getReplicationFactor() - Method in class com.linkedin.venice.meta.StoreInfo
 
getReplicationFactor() - Method in class com.linkedin.venice.meta.SystemStore
 
getReplicationFactor() - Method in interface com.linkedin.venice.meta.Version
 
getReplicationFactor() - Method in class com.linkedin.venice.meta.VersionImpl
 
getReplicationFactor() - Method in class com.linkedin.venice.meta.ZKStore
 
getReplicationFactor() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getReplicationFactor() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'replicationFactor' field.
getReplicationFactor() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'replicationFactor' field.
getReplicationFactor(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getReplicationFactor(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getReplicationFactor(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getReplicationMetadata(byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
This API retrieves replication metadata from replicationMetadataColumnFamily.
getReplicationMetadata(byte[]) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
getReplicationMetadata(int, byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getReplicationMetadata(AbstractStorageEngine, int, byte[], boolean, ReadResponse, ChunkedValueManifestContainer) - Static method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
 
getReplicationMetadataPayload() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Gets the value of the 'replicationMetadataPayload' field.
getReplicationMetadataPayload() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
 
getReplicationMetadataPayload() - Method in class com.linkedin.venice.kafka.protocol.Delete
Gets the value of the 'replicationMetadataPayload' field.
getReplicationMetadataPayload() - Method in class com.linkedin.venice.kafka.protocol.Put
Gets the value of the 'replicationMetadataPayload' field.
getReplicationMetadataProtocolVersion() - Method in class com.linkedin.venice.schema.rmd.RmdVersionId
 
getReplicationMetadataRecord() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
getReplicationMetadataSchema(int, int) - Method in class com.linkedin.venice.schema.SchemaData
 
getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getReplicationMetadataSchema(String, int, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
 
getReplicationMetadataSchema(String, String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getReplicationMetadataSchema(String, String, int, int) - Method in interface com.linkedin.venice.controller.Admin
 
getReplicationMetadataSchema(String, String, int, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getReplicationMetadataSchema(String, String, int, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getReplicationMetadataSchemaById(String, int) - Method in class com.linkedin.davinci.consumer.ReplicationMetadataSchemaRepository
 
getReplicationMetadataSchemas() - Method in class com.linkedin.venice.schema.SchemaData
 
getReplicationMetadataSchemas(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getReplicationMetadataSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getReplicationMetadataSchemas(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
 
getReplicationMetadataSchemas(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getReplicationMetadataSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getReplicationMetadataSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getReplicationMetadataVersion() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getReplicationMetadataVersionId() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Gets the value of the 'replicationMetadataVersionId' field.
getReplicationMetadataVersionId() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
 
getReplicationMetadataVersionId() - Method in class com.linkedin.venice.kafka.protocol.Delete
Gets the value of the 'replicationMetadataVersionId' field.
getReplicationMetadataVersionId() - Method in class com.linkedin.venice.kafka.protocol.Put
Gets the value of the 'replicationMetadataVersionId' field.
getReplicationMetadataVersionId() - Method in class com.linkedin.venice.meta.StoreInfo
 
getReplicationMetadataVersionID() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'replicationMetadataVersionID' field.
getReplicationMetadataVersionID() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getReplicationMetadataVersionID() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'replicationMetadataVersionID' field.
getReporter() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getReportTimestamp() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
Gets the value of the 'reportTimestamp' field.
getReportTimestamp() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'reportTimestamp' field.
getReportType() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'reportType' field.
getRepushInfo() - Method in class com.linkedin.venice.controllerapi.RepushInfoResponse
 
getRepushInfo(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getRepushInfo(String, String, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
 
getRepushInfo(String, String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getRepushInfo(String, String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getRepushInfo(String, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getRepushTtlFilterCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getRepushTtlFilterCount() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getRepushTtlFilterCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getRepushTtlFilterCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getRepushViability() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
getRequestContentLength() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
The content length of the request body in bytes, as retrieved by the header, or -1 if not known.
getRequestContentLength() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
GetRequestContext - Class in com.linkedin.venice.fastclient
 
getRequestHeaders() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
The request headers.
getRequestHeaders() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
getRequestId() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
A computed UUID for the request
getRequestId() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Returns the computed request ID of the packet, which is intended to be reasonably unique.
getRequestId() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getRequestKeyCount() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getRequestKeyCount() - Method in exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
 
getRequestNanos() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
High precision nanotime at which the request was received.
getRequestNanos() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Returns the nanotime of the first packet of which formed this request object.
getRequestPartCount() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getRequestParts(String) - Static method in class com.linkedin.venice.request.RequestHelper
Parses the '/' separated parts of a request uri.
getRequestPathByKey(K) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getRequestRate() - Method in class com.linkedin.venice.client.stats.BasicClientStats
 
getRequestSize() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getRequestStartTimeInNS() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getRequestStartTimeInNS() - Method in class com.linkedin.venice.listener.StatsHandler
 
getRequestTimeout(Headers) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
getRequestTimestamp() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
Timestamp at which the request was received.
getRequestTimestamp() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Returns the timestamp of the first packet of which formed this request object.
getRequestTimestamp(Object) - Static method in interface com.linkedin.alpini.base.misc.BasicRequest
 
getRequestType() - Method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
 
getRequestType() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
 
getRequestType() - Method in class com.linkedin.venice.listener.request.MultiGetRouterRequestWrapper
 
getRequestType() - Method in class com.linkedin.venice.listener.request.RouterRequest
 
getRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
getRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
getRequestType() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
getRequestType() - Method in exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
 
getRequestType() - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
 
getRequired(T) - Static method in class com.linkedin.venice.security.SSLConfig.ConfigHelper
 
getRequiredArgs() - Method in enum com.linkedin.venice.Command
 
getRequiredField(Map<String, String>, String) - Static method in class com.linkedin.venice.status.StatusMessage
 
getRequiredObject(Object) - Static method in class com.linkedin.venice.security.SSLConfig.ConfigHelper
 
getReservedVersion() - Method in class com.linkedin.venice.meta.StoreInfo
The highest version number that has been reserved.
getResource() - Method in class com.linkedin.venice.authorization.AclBinding
 
getResource() - Method in exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
 
getResource() - Method in class com.linkedin.venice.helix.Replica
 
getResourceAssignment() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
getResourceAssignment() - Method in interface com.linkedin.venice.meta.RoutingDataRepository
 
getResourceName() - Method in interface com.linkedin.alpini.router.api.ResourcePath
 
getResourceName() - Method in class com.linkedin.venice.listener.request.DictionaryFetchRequest
 
getResourceName() - Method in class com.linkedin.venice.listener.request.RouterRequest
 
getResourceName() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
Gets the value of the 'resourceName' field.
getResourceName() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string resourceName = 5;
getResourceName() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
string resourceName = 5;
getResourceName() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
string resourceName = 5;
getResourceName() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getResourceName() - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
 
getResourceName(String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
getResourceNameBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string resourceName = 5;
getResourceNameBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
string resourceName = 5;
getResourceNameBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
string resourceName = 5;
getResources() - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
 
getResourceType() - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
 
getResponseBody() - Method in class com.linkedin.davinci.listener.response.AdminResponse
 
getResponseBody() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
getResponseBody() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getResponseBody() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
 
getResponseBody() - Method in class com.linkedin.venice.listener.response.StorageResponseObject
 
getResponseCode(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
getResponseCode(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
getResponseDecompressor() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getResponseHeaders() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getResponseHeaders(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
getResponseHeaders(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
getResponseObserver() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
getResponseRCU() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 responseRCU = 4;
getResponseRCU() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
uint32 responseRCU = 4;
getResponseRCU() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
uint32 responseRCU = 4;
getResponseReadable(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
getResponseReadable(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
getResponseRecord() - Method in class com.linkedin.davinci.listener.response.AdminResponse
 
getResponseRecord() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
getResponseSchemaIdHeader() - Static method in class com.linkedin.davinci.listener.response.AdminResponse
 
getResponseSchemaIdHeader() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
getResponseSchemaIdHeader() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.ComputeResponseWrapper
 
getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.MultiGetResponseWrapper
 
getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
 
getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.StorageResponseObject
 
getResponseSerializer() - Method in class com.linkedin.venice.listener.response.ComputeResponseWrapper
 
getResponseSerializer() - Method in class com.linkedin.venice.listener.response.MultiGetResponseWrapper
 
getResponseSerializer() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
 
getResponseStatus() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getResponseStatus(Throwable) - Method in class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
 
getRestServiceStorageThreadNum() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getResult() - Method in class com.linkedin.alpini.base.statistics.Welfords
 
getResult() - Method in class com.linkedin.venice.datarecovery.Command
 
getResult() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
getResult() - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
getResult() - Method in class com.linkedin.venice.datarecovery.MonitorCommand
 
getResult() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
Gets the value of the 'resultFieldName' field.
getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.Count
Gets the value of the 'resultFieldName' field.
getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
Gets the value of the 'resultFieldName' field.
getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
Gets the value of the 'resultFieldName' field.
getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
 
getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CountOperator
 
getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.DotProductOperator
 
getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.HadamardProductOperator
 
getResultFieldName(ComputeOperation) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
 
getResultFuture() - Method in class com.linkedin.venice.utils.concurrent.ChainedCompletableFuture
 
getResultSchema() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
getResultSchema() - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
 
getResultSchemaStr() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
 
getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
Gets the value of the 'resultSchemaStr' field.
getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
Gets the value of the 'resultSchemaStr' field.
getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
Gets the value of the 'resultSchemaStr' field.
getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
Gets the value of the 'resultSchemaStr' field.
getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
Gets the value of the 'resultSchemaStr' field.
getRetentionTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getRetentionTime() - Method in interface com.linkedin.venice.meta.Store
 
getRetentionTime() - Method in class com.linkedin.venice.meta.SystemStore
 
getRetentionTime() - Method in class com.linkedin.venice.meta.ZKStore
Get the retention time for the RT Topic.
getRetriableExceptions() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
 
getRetriableExceptions() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
getRetryBackOffInMs() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getRetryCount() - Method in class com.linkedin.alpini.base.misc.RetryCounter
 
getRetryCount() - Method in class com.linkedin.alpini.base.misc.RetryCountSlidingWindow
 
getRetryCount() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getRetryRatio() - Method in class com.linkedin.alpini.base.misc.RetryCountSlidingWindow
 
getRetryTokenBucket() - Method in class com.linkedin.venice.fastclient.meta.RetryManager
 
getRewindStartTimestamp() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
Gets the value of the 'rewindStartTimestamp' field.
getRewindTimeInSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Gets the value of the 'rewindTimeInSeconds' field.
getRewindTimeInSeconds() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
getRewindTimeInSeconds() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
getRewindTimeInSeconds() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
Gets the value of the 'rewindTimeInSeconds' field.
getRewindTimeInSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Gets the value of the 'rewindTimeInSeconds' field.
getRewindTimeInSecondsOverride() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'rewindTimeInSecondsOverride' field.
getRFC1036Date(long) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
getRFC1036Date(Date) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
getRFC1123Date(long) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
getRFC1123Date(Date) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
getRingEntry(String) - Method in class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
Returns the ring entry for queueName or creates a new ring entry as required.
getRmd() - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
getRmdByteUsage() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
getRmdByteUsage() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
getRmdByteUsage() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getRmdChunkingEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'rmdChunkingEnabled' field.
getRmdChunkingEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getRmdChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'rmdChunkingEnabled' field.
getRmdChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'rmdChunkingEnabled' field.
getRmdManifest() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
getRmdManifest() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
getRmdPayload() - Method in class com.linkedin.venice.writer.DeleteMetadata
 
getRmdPayload() - Method in class com.linkedin.venice.writer.PutMetadata
 
getRmdPayload(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
 
getRmdPayload(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
 
getRmdPayload(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
getRmdProtocolId(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
 
getRmdProtocolId(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
 
getRmdProtocolId(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
getRmdProtocolVersionId() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
getRmdRecord() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
 
getRmdRecord() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
getRmdSchema(int) - Method in class com.linkedin.davinci.replication.merge.RmdSerDe
 
getRmdSchema(int, int) - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
Retrieve RMD schema and annotate map field and string array field's deleted elements list field.
getRmdSchemaPath() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
 
getRmdSerDe() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
getRMDSizeInBytes() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getRMDSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
getRmdTimestampType(Object) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
Returns the type of union record given tsObject is.
getRmdValueSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
getRmdVersion() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getRmdVersion() - Method in interface com.linkedin.venice.meta.Store
 
getRmdVersion() - Method in class com.linkedin.venice.meta.SystemStore
 
getRmdVersion() - Method in class com.linkedin.venice.meta.ZKStore
 
getRmdVersionId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
 
getRmdVersionId() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getRmdVersionId() - Method in interface com.linkedin.venice.meta.Version
 
getRmdVersionId() - Method in class com.linkedin.venice.meta.VersionImpl
 
getRmdVersionId() - Method in class com.linkedin.venice.writer.DeleteMetadata
 
getRmdVersionId() - Method in class com.linkedin.venice.writer.PutMetadata
 
getRocksDBAggregatedStatistics() - Method in class com.linkedin.davinci.storage.StorageService
 
getRocksDBBlockCacheImplementation() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBBlockCacheShardBits() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBBlockCacheSizeInBytes() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getRocksDBBlockCacheSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBBlockCacheStrictCapacityLimit() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBBloomBitsPerKey() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBBytesPerSync() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBEnvCompactionPoolSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBEnvFlushPoolSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBHugePageTlbSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBMaxBytesForLevelBase() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBMaxMemtableCount() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBMaxTotalWalSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBMemtableSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBOptionsCompactionStyle() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBOptionsCompressionType() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBPath(String, int) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getRocksDBRMDBlockCacheSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBServerConfig() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getRocksDBSSTFileBlockSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBSstFileWriter() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
getRocksDBSstFileWriter() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getRocksDBStatValue(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
getRocksDBTotalMemtableUsageCapInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRocksDBUseDirectReads() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getRole() - Method in class com.linkedin.alpini.router.api.Scatter
 
getRootStatus() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
getRoute() - Static method in class com.linkedin.venice.controller.server.NotImplemented
 
getRouteHttpRequestStats() - Method in class com.linkedin.venice.router.api.VeniceDispatcher
For TEST ONLY
getRouteId() - Method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
 
getRouterAccessController() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getRouterClientConfig() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getRouterConnectionWarmingDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getRouterDictionaryProcessingThreads() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRouteRequestFuture() - Method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
 
getRouterIOWorkerCount() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRouterNettyGracefulShutdownPeriodSeconds() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRouterPendingConnResumeThresholdPerRoute() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRouterPrincipalName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getRouterQuotaCheckWindow() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRouterRequest() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
GetRouterRequest - Class in com.linkedin.venice.listener.request
GetRouterRequest encapsulates a GET request to storage/resourcename/partition/key on the storage node for a single-get operation.
getRouterRootPath() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
getRoutersClusterConfig() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getRoutersClusterConfig() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
getRoutersClusterConfig(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
No ACL check; any user is allowed to check router cluster configs.
getRoutersClusterConfig(String) - Method in interface com.linkedin.venice.controller.Admin
Get the cluster level config for all routers.
getRoutersClusterConfig(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getRoutersClusterConfig(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getRoutersClusterManager() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getRoutersClusterManager() - Method in class com.linkedin.venice.router.RouterServer
 
getRouterUnhealthyPendingConnThresholdPerRoute() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getRoutesForPartitionMapping() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
 
getRoutingDataRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getRoutingDataRepository() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getRoutingDataRepository() - Method in class com.linkedin.venice.router.RouterServer
 
getRoutingErrorRequestCounterResetDelayMS() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getRoutingInfo() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'routingInfo' field.
getRoutingLeakedRequestCleanupThresholdMS() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getRoutingPendingRequestCounterInstanceBlockThreshold() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getRoutingQuotaExceededRequestCounterResetDelayMS() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getRoutingStrategy() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getRoutingStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getRoutingStrategy() - Method in interface com.linkedin.venice.meta.Store
 
getRoutingStrategy() - Method in class com.linkedin.venice.meta.SystemStore
 
getRoutingStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'routingStrategy' field.
getRoutingStrategy() - Method in class com.linkedin.venice.meta.ZKStore
 
getRoutingStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'routingStrategy' field.
getRoutingStrategyFromInt(int) - Static method in enum com.linkedin.venice.meta.RoutingStrategy
 
getRoutingUnavailableRequestCounterResetDelayMS() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getRstErrorCount() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
getRstErrorCount() - Method in interface com.linkedin.alpini.router.impl.Router
 
getRunnableForKillIngestionTasksForNonCurrentVersions() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getRunningFabric() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
getRWLockForPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Making it public is for testing purpose.
getRWLockForPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
getSanitizedStringForLogger(String) - Static method in class com.linkedin.venice.utils.Utils
Log4J's class name logging splits at the last "." and assumes it is the class name.
getScatterGatherHelper() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
getScatterGatherHelper() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
getScatterGatherStatsByPath(P) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
getScatterGatherStatsForStore(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
getScheduler() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getSchema() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
getSchema() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
getSchema() - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
getSchema() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
getSchema() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
getSchema() - Method in class com.linkedin.venice.client.schema.SchemaAndToString
 
getSchema() - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
 
getSchema() - Method in class com.linkedin.venice.client.store.schemas.TestKeyRecord
 
getSchema() - Method in class com.linkedin.venice.client.store.schemas.TestValueRecord
 
getSchema() - Method in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
getSchema() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.Count
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
getSchema() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
getSchema() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
getSchema() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
getSchema() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
getSchema() - Method in enum com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
 
getSchema() - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
getSchema() - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
getSchema() - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.Delete
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.GUID
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.Put
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.Update
 
getSchema() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
getSchema() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
getSchema() - Method in class com.linkedin.venice.metadata.response.VersionProperties
 
getSchema() - Method in class com.linkedin.venice.participant.protocol.KillPushJob
 
getSchema() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
getSchema() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
getSchema() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
getSchema() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
 
getSchema() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
 
getSchema() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
getSchema() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
getSchema() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
getSchema() - Method in enum com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
 
getSchema() - Method in class com.linkedin.venice.schema.SchemaEntry
 
getSchema() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
getSchema() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
getSchema() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
 
getSchema() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
getSchema() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
getSchema() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
getSchema() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
getSchema() - Method in class com.linkedin.venice.storage.protocol.ChunkId
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
getSchema() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
getSchema$() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Gets the value of the 'schema' field.
getSchema$() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Gets the value of the 'schema' field.
getSchemaAdapter(Schema.Type) - Static method in interface com.linkedin.venice.schema.SchemaAdapter
Checks if it is possible for some value to be modified to adapt to the provided schema type.
getSchemaAutoRegisteFromPushJobEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'schemaAutoRegisteFromPushJobEnabled' field.
getSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
getSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
getSchemaBytes() - Method in class com.linkedin.venice.schema.SchemaEntry
 
getSchemaDataFromMetaSystemStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getSchemaDataFromSystemStore(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getSchemaDataFromSystemStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getSchemaDataFromSystemStore(String) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
 
getSchemaDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
 
getSchemaDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
 
getSchemaFromResource(String) - Static method in class com.linkedin.venice.utils.Utils
Utility function to get schemas out of embedded resources.
getSchemaId() - Method in class com.linkedin.davinci.store.record.ValueRecord
 
getSchemaId() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
Gets the value of the 'schemaId' field.
getSchemaId() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
 
getSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Gets the value of the 'schemaId' field.
getSchemaId() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Gets the value of the 'schemaId' field.
getSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Delete
Gets the value of the 'schemaId' field.
getSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Put
Gets the value of the 'schemaId' field.
getSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Update
Gets the value of the 'schemaId' field.
getSchemaId() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
sint32 schemaId = 1;
getSchemaId() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
sint32 schemaId = 1;
getSchemaId() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
sint32 schemaId = 1;
getSchemaId() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Gets the value of the 'schemaId' field.
getSchemaId() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
Gets the value of the 'schemaId' field.
getSchemaId(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
 
getSchemaId(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
 
getSchemaId(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
getSchemaID() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
 
getSchemaID(SchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
 
getSchemaIds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
Gets the value of the 'schemaIds' field.
getSchemaIdSet() - Method in class com.linkedin.venice.controllerapi.MultiSchemaIdResponse
 
getSchemaReader() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getSchemaReader() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getSchemaReader(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getSchemaReader(ClientConfig, ICProvider) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getSchemaRefreshPeriod() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getSchemaRepo() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getSchemaRepo() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getSchemaRepo() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
getSchemaRepository() - Method in class com.linkedin.davinci.DaVinciBackend
 
getSchemaRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getSchemaRepository() - Method in class com.linkedin.venice.router.RouterServer
 
getSchemas() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse
 
getSchemaStr() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
getSchemaStr() - Method in class com.linkedin.venice.controllerapi.SchemaResponse
 
getSchemaStr() - Method in class com.linkedin.venice.schema.SchemaEntry
 
getSchemaType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
Gets the value of the 'schemaType' field.
getSecond() - Method in class com.linkedin.alpini.base.misc.Pair
Return the second value.
getSecond() - Method in class com.linkedin.venice.utils.Pair
Deprecated.
 
getSecondPartLatency() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getSeconds() - Method in class com.linkedin.venice.utils.MockCircularTime
 
getSeconds() - Method in class com.linkedin.venice.utils.SystemTime
 
getSecureRandomAlgorithm() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getSecureUrl() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
 
getSegmentNumber() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Gets the value of the 'segmentNumber' field.
getSegmentNumber() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'segmentNumber' field.
getSegmentNumber() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getSegmentNumber() - Method in class com.linkedin.venice.storage.protocol.ChunkId
Gets the value of the 'segmentNumber' field.
getSegmentStatus() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Gets the value of the 'segmentStatus' field.
getSendLivenessHeartbeatFailureDetails() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'sendLivenessHeartbeatFailureDetails' field.
getSensorFullName(String) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
getSensorFullName(String, String) - Static method in class com.linkedin.venice.stats.AbstractVeniceStats
 
getSequence() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
getSequenceNumber() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getSequenceNumber() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getSerializableSystemStore() - Method in class com.linkedin.venice.meta.SystemStore
 
getSerializedKey() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext.KeyInfo
 
getSerializedSize() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
getSerializedSize() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
getSerializedSize() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
 
getSerializedSize() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
Sum of the size of the serialized, uncompressed key and value in bytes.
getSerializedSize() - Method in class com.linkedin.venice.writer.DeleteMetadata
 
getSerializedSize() - Method in class com.linkedin.venice.writer.PutMetadata
 
getSerializer() - Method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
 
getSerializer(Schema) - Static method in class com.linkedin.davinci.serializer.avro.fast.MapOrderPreservingFastSerDeFactory
 
getSerializer(Schema) - Static method in class com.linkedin.davinci.serializer.avro.MapOrderPreservingSerDeFactory
 
getSerializer(Schema) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
getServerAdminAction() - Method in class com.linkedin.venice.listener.request.AdminRequest
 
getServerComputeThreadNum() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getServerConfig() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getServerConfig() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getServerConfigs() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Gets the value of the 'serverConfigs' field.
getServerD2Service() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
getServerD2Service(String) - Method in interface com.linkedin.venice.controller.Admin
Find the server d2 service associated with a given cluster name.
getServerD2Service(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getServerD2Service(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getServerHttp2Settings() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
getServerIncrementalPushKey(int, int, String, String) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
 
getServerKafkaFetchQuotaRecordsPerSecond() - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
getServerKafkaFetchQuotaRecordsPerSecond() - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
getServerKafkaFetchQuotaRecordsPerSecondForRegion(String) - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
getServerMaxWaitForVersionInfo() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getServerPromotionToLeaderReplicaDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getServerStatsContext() - Method in class com.linkedin.venice.listener.StatsHandler
 
getServerSystemStorePromotionToLeaderReplicaDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getService() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
 
getServiceDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
 
getServiceDiscoveryAnnouncers() - Method in class com.linkedin.venice.controller.VeniceControllerContext
 
getServiceDiscoveryAnnouncers() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getServiceName() - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
getSessionCacheSize() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getSessionId() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getSessionStartTime() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getSessionTimeout() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getSharedCache(boolean) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getSharedConsumerAssignmentStrategy() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getSharedConsumerNonExistingTopicCleanupDelayMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getShellCmd() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
getShort(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getShort(CharSequence, short) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getSingleGetRouterCacheEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'singleGetRouterCacheEnabled' field.
getSingleGetRouterCacheEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'singleGetRouterCacheEnabled' field.
getSingleGetTardyLatencyThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getSize() - Method in interface com.linkedin.venice.common.Measurable
 
getSize() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
Gets the value of the 'size' field.
getSizeInBytes(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getSizeInBytes(String, long) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getSmartLongTailRetryAbortThresholdMs() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getSmartLongTailRetryAbortThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getSnapshot() - Method in interface com.linkedin.alpini.router.api.HostFinder
 
getSocketTimeout() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getSomeTopicConfigs(Set<PubSubTopic>) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Retrieves the configurations for a set of Kafka topics.
getSomeTopicConfigs(Set<PubSubTopic>) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Retrieves the configurations for a set of PubSub topics.
getSomeTopicConfigs(Set<PubSubTopic>) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getSomeTopicConfigs(Set<PubSubTopic>) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
getSorted() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Gets the value of the 'sorted' field.
getSorted() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'sorted' field.
getSourceBrokerLeaderConsumerLatencySensor() - Method in class com.linkedin.davinci.stats.DIVStats
 
getSourceCluster() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Gets the value of the 'sourceCluster' field.
getSourceConsumerRecord() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
getSourceFabric() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getSourceKafkaCluster() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Gets the value of the 'sourceKafkaCluster' field.
getSourceKafkaServers() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
Gets the value of the 'sourceKafkaServers' field.
getSourceOffsets() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Gets the value of the 'sourceOffsets' field.
getSourceServers() - Method in class com.linkedin.davinci.kafka.consumer.TopicSwitchWrapper
 
getSourceTopicName() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Gets the value of the 'sourceTopicName' field.
getSourceTopicName() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
Gets the value of the 'sourceTopicName' field.
getSourceTopicPartition(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getSourceTopicPartitionNumber(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getSparkSession() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
getSpecificAvroClient(ClientConfig<V>) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
getSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
 
getSpecificData() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
getSpecificData() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
getSpecificData() - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
getSpecificData() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
getSpecificData() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
getSpecificData() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.Count
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
getSpecificData() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
getSpecificData() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
getSpecificData() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
getSpecificData() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
getSpecificData() - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.Delete
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.Put
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.Update
 
getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
getSpecificData() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
getSpecificData() - Method in class com.linkedin.venice.metadata.response.VersionProperties
 
getSpecificData() - Method in class com.linkedin.venice.participant.protocol.KillPushJob
 
getSpecificData() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
getSpecificData() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
getSpecificData() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
getSpecificData() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
 
getSpecificData() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
 
getSpecificData() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
getSpecificData() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
getSpecificData() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
getSpecificData() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
getSpecificData() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
getSpecificData() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
 
getSpecificData() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
getSpecificData() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
getSpecificData() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
getSpecificData() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
getSpecificData() - Method in class com.linkedin.venice.storage.protocol.ChunkId
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
getSpecificData() - Method in class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
Returns the SpecificData implementation used by this writer.
getSpecificThinClient() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getSpecificValueClass() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getSpecificValueClass() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getSplits(JobConf, int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
Split the topic according to the topic partition size and the allowed max record per mapper.
getSplits(JobConf, int) - Method in class com.linkedin.venice.hadoop.VeniceFileInputFormat
Number of splits is set to be always 1: which will invoke only 1 mapper to handle all the files.
getSplitsByRecordsPerSplit(JobConf, long) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
 
getSprayAllPartitionsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getSprayAllPartitionsCount() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getSprayAllPartitionsCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getSrcClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
Gets the value of the 'srcClusterName' field.
getSrcClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
Gets the value of the 'srcClusterName' field.
getSrcClusterName() - Method in class com.linkedin.venice.controllerapi.StoreMigrationResponse
 
getSsdHealthCheckShutdownTimeMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getSslConfig() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getSslConfig() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getSslConfig() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getSSLConfig() - Method in class com.linkedin.venice.security.DefaultSSLFactory
 
getSSLConfig() - Method in interface com.linkedin.venice.security.SSLFactory
 
getSSLConfig() - Method in class com.linkedin.venice.SSLConfig
 
getSSLConfigurator(String) - Static method in interface com.linkedin.venice.hadoop.ssl.SSLConfigurator
 
getSSLContext() - Method in interface com.linkedin.alpini.base.ssl.SslFactory
 
getSSLContext() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
getSSLContext() - Method in class com.linkedin.venice.security.DefaultSSLFactory
 
getSSLContext() - Method in interface com.linkedin.venice.security.SSLFactory
 
getSslContextProvider() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getSslEnabled() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getSslEnabled() - Method in class com.linkedin.venice.security.SSLConfig
 
getSslFactory() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getSslFactory() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getSslFactory() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig
 
getSslFactory() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
 
getSslFactory() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getSSLFactory() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
 
getSSLFactory() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
 
getSSLFactory() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getSSLFactory(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
getSSLFactory(Properties, String) - Static method in class com.linkedin.venice.utils.SslUtils
A helper function that return an instance of SSLFactory with ssl Properties.
getSslFactoryClassName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getSslFactoryClassName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getSSLFactoryForIngestion(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
Create SSLFactory for D2Client in ClientConfig, which will be used by different ingestion components.
getSslHandshakeQueueCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getSslHandshakeThreadPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getSslKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getSslKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getSslKeyStoreLocation() - Method in class com.linkedin.venice.SSLConfig
 
getSslKeyStorePassword() - Method in class com.linkedin.venice.SSLConfig
 
getSSLParameters() - Method in interface com.linkedin.alpini.base.ssl.SslFactory
 
getSSLParameters() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
getSSLParameters() - Method in class com.linkedin.venice.security.DefaultSSLFactory
 
getSSLParameters() - Method in interface com.linkedin.venice.security.SSLFactory
 
getSslPort() - Method in class com.linkedin.venice.meta.Instance
 
getSslPort() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getSslProperties() - Method in class com.linkedin.venice.SSLConfig
 
getSslProperties(VeniceProperties) - Static method in class com.linkedin.venice.hadoop.utils.VPJSSLUtils
Build a ssl properties based on the hadoop token file.
getSslProtocol() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getSslStrategy(SSLFactory) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
 
getSslTrustStoreLocation() - Method in class com.linkedin.venice.SSLConfig
 
getSslTrustStorePassword() - Method in class com.linkedin.venice.SSLConfig
 
getSstFileManager() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getSstFileManagerForMemoryLimiter() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getStackTrace(Throwable) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
 
getStaleRegions() - Method in class com.linkedin.venice.meta.StoreDataAudit
 
getStaleStoresInCluster(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getStaleTokenCount() - Method in class com.linkedin.venice.throttle.TokenBucket
This method does not call #update(), so it is only accurate as of the last time #tryConsume() was called
getStaleUsageRatio() - Method in class com.linkedin.venice.throttle.TokenBucket
 
getStandardDeviation() - Method in interface com.linkedin.alpini.base.statistics.LongStats
Returns the standard deviation.
getStandardDeviation() - Method in interface com.linkedin.alpini.base.statistics.LongStatsLowQuantile
Returns the standard deviation.
getStandardDeviation() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
getStandardDeviation() - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
getStartCount() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getStartCount() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getStartCount() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getStartedVersion(Store) - Static method in class com.linkedin.venice.controller.VeniceHelixAdmin
The intended semantic is to use this method to find the version that something is currently pushing to.
getStartFrequency() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getStartFrequency() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getStartFrequency() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getStartFrequency15min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getStartFrequency15min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getStartFrequency1min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getStartFrequency1min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getStartFrequency5min() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker.CallStats
 
getStartFrequency5min() - Method in class com.linkedin.alpini.base.pool.impl.NullStats
 
getStartingOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
Returns the starting offset for the split
getStartOfBufferReplay() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'startOfBufferReplay' field.
getStartOfBufferReplayDestinationOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'startOfBufferReplayDestinationOffset' field.
getStartOfPushTimestamp() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getStartOfPushTimestamp() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'startOfPushTimestamp' field.
getStartProcessingTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
 
getStartTime() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
getStartTimeMillis() - Method in class com.linkedin.alpini.base.misc.TouchTimer
 
getStartTimeNanos() - Method in class com.linkedin.alpini.base.misc.TouchTimer
 
getStartTimeSec() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getStatCallback(ClientStats, long) - Static method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
getStateMachineEngine() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getStateModelID(String, int) - Static method in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
getStates() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
Gets the value of the 'states' field.
getStateTransitionStats(String) - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
Use the right state transition stats for the resource.
getStateTransitionStats(String) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelDualPoolFactory
 
getStateValue() - Method in enum com.linkedin.venice.helix.HelixState
 
getStats() - Method in class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
 
getStats() - Method in class com.linkedin.davinci.StoreBackend
 
getStats() - Method in class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
 
getStats() - Method in interface com.linkedin.venice.client.store.streaming.TrackingStreamingCallback
 
getStats() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
getStats(int) - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
getStats(RequestType) - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getStats(String, int) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
getStatsByType(RequestType) - Method in class com.linkedin.venice.router.stats.RouterStats
 
getStatsPrefix() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getStatus() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
getStatus() - Method in interface com.linkedin.venice.hadoop.jobs.ComputeJob
 
getStatus() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
getStatus() - Method in class com.linkedin.venice.helix.Replica
 
getStatus() - Method in class com.linkedin.venice.kafka.validation.Segment
 
getStatus() - Method in class com.linkedin.venice.listener.response.BinaryResponse
 
getStatus() - Method in class com.linkedin.venice.listener.response.HttpShortcutResponse
 
getStatus() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getStatus() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'status' field.
getStatus() - Method in class com.linkedin.venice.meta.UncompletedReplica
 
getStatus() - Method in interface com.linkedin.venice.meta.Version
 
getStatus() - Method in class com.linkedin.venice.meta.VersionImpl
 
getStatus() - Method in class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
 
getStatus() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
 
getStatus() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Gets the value of the 'status' field.
getStatus() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
Gets the value of the 'status' field.
getStatus() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
getStatus() - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
Gets the value of the 'status' field.
getStatus() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'status' field.
getStatus(AsyncFuture<?>) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
 
getStatusCode() - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
 
getStatusCode() - Method in enum com.linkedin.venice.utils.VeniceResourceCloseResult
 
getStatusDetails() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
getStatusDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
Deprecated.
Only used for JSON serialization purposes. Use JobStatusQueryResponse.getOptionalExtraDetails() instead.
getStatusDetails() - Method in class com.linkedin.venice.meta.UncompletedReplica
 
getStatusDetails() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
Necessary for the JSON serde
getStatusHistory() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getStatusHistory() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
getStatusReportAdapter() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getStatusStoreWriter() - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
getStatusUpdateTimestamp() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
getStatusUpdateTimestamp() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
N.B.: Older versions of the controller did not support this timestamp, so this can be null.
getStatusUpdateTimestamp() - Method in class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
N.B.: This is not available in older controller versions, and not available for all statuses (e.g.
getStatusUpdateTimestamp() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getStdOut() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
 
getStopConsumptionTimeoutInSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getStopConsumptionTimeoutInSeconds() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getStorageClass() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
getStorageEngine() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.StorageEngineFactory
Get an initialized storage implementation
getStorageEngine(VeniceStoreVersionConfig, boolean) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getStorageEngine(VeniceStoreVersionConfig, boolean) - Method in class com.linkedin.davinci.store.StorageEngineFactory
Replication metadata is only supported in RocksDB storage engine.
getStorageEngine(String) - Method in class com.linkedin.davinci.storage.StorageService
 
getStorageEngine(String) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
getStorageEngineOverheadRatio() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getStorageEngineOverheadRatio() - Method in class com.linkedin.venice.controllerapi.StorageEngineOverheadRatioResponse
 
getStorageEngineOverheadRatio(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getStorageEngineOverheadRatio(String) - Method in interface com.linkedin.venice.controller.Admin
 
getStorageEngineOverheadRatio(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStorageEngineOverheadRatio(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getStorageEngineOverheadRatio(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getStorageEngineRepository() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getStorageEngineRepository() - Method in class com.linkedin.davinci.storage.StorageService
 
getStorageExecutionHandlerSubmissionWaitTime() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getStorageExecutionQueueLen() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getStorageMetadataService() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getStorageMetadataService() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getStorageMetadataService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getStorageMetadataService() - Method in class com.linkedin.venice.server.VeniceServer
 
getStorageNodeClientType() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'storageNodeReadQuotaEnabled' field.
getStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'storageNodeReadQuotaEnabled' field.
getStorageNodes(String) - Method in interface com.linkedin.venice.controller.Admin
 
getStorageNodes(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStorageNodes(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getStorageNodesStatus(String, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
getStorageNodesStatus(String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStorageNodesStatus(String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getStorageNodesStatus(String, String) - Method in interface com.linkedin.venice.controller.Admin
Query and return the current status of the given storage node.
getStorageNodesStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStorageNodesStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
getStoragePersona() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'storagePersona' field.
getStoragePersona() - Method in class com.linkedin.venice.controllerapi.StoragePersonaResponse
 
getStoragePersona() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getStoragePersona(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
 
getStoragePersona(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getStoragePersona(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getStoragePersonaAssociatedWithStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getStoragePersonaRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getStoragePersonas() - Method in class com.linkedin.venice.controllerapi.MultiStoragePersonaResponse
 
getStorageQuotaInByte() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'storageQuotaInByte' field.
getStorageQuotaInByte() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getStorageQuotaInByte() - Method in interface com.linkedin.venice.meta.Store
 
getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.StoreInfo
 
getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.SystemStore
 
getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'storageQuotaInByte' field.
getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.ZKStore
 
getStorageQuotaInByte() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'storageQuotaInByte' field.
getStorageService() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getStorageService() - Method in class com.linkedin.venice.server.VeniceServer
 
getStore() - Method in class com.linkedin.venice.controllerapi.StoreResponse
 
getStore() - Method in class com.linkedin.venice.datarecovery.Command.Params
 
getStore() - Method in class com.linkedin.venice.datarecovery.Command.Result
 
getStore() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskParams
 
getStore() - Method in class com.linkedin.venice.store.StoreStateReader
 
getStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getStore(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getStore(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
getStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
Only the zk shared system store can be returned, otherwise this function will return null.
getStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
getStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepositoryAdapter
 
getStore(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Get one store by given name from repository.
getStore(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getStore(String, String, String) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
Deprecated.
getStoreAccessController() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getStoreAndServerConfigs() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
getStoreAndUserPartitionsMapping() - Method in class com.linkedin.davinci.storage.StorageService
 
getStoreBufferService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getStoreCacheConfig() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
To avoid cycle dependency, we need to initialize another store client for schema reader.
getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
To avoid cycle dependency, we need to initialize another store client for schema reader.
getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
To avoid cycle dependency, we need to initialize another store client for schema reader.
getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
Deprecated.
 
getStoreClusterConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'storeClusterConfig' field.
getStoreConfig(String) - Method in class com.linkedin.davinci.config.VeniceConfigLoader
 
getStoreConfig(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
The corresponding Venice store config is returned for metadata system store's store config.
getStoreConfig(String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
getStoreConfig(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreConfigRepository
 
getStoreConfig(String, PersistenceType) - Method in class com.linkedin.davinci.config.VeniceConfigLoader
 
getStoreConfigAccessor() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getStoreConfigAddedOrDeletedListener() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
getStoreConfigChangedListener() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
getStoreConfigFromMetaSystemStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getStoreConfigFromSystemStore(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getStoreConfigFromSystemStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getStoreConfigFromSystemStore(String) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
 
getStoreConfigOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
getStoreConfigOrThrow(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreConfigRepository
 
getStoreConfigRepo() - Method in interface com.linkedin.venice.controller.Admin
Return a shared store config repository.
getStoreConfigRepo() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStoreConfigRepo() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getStoreConfigs(List<String>) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
getStoreDeserializerCache() - Method in class com.linkedin.davinci.StoreBackend
 
getStoreFromGraveyard(String, String, Stat) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
 
getStoreFromGraveyard(String, String, Stat) - Method in interface com.linkedin.venice.meta.StoreGraveyard
Get store from the graveyard in the specified cluster.
getStoreFromSystemStore(String, String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getStoreFromSystemStore(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getStoreFromSystemStore(String, String) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
 
getStoreFromZk(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getStoreGraveyard() - Method in interface com.linkedin.venice.controller.Admin
 
getStoreGraveyard() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getStoreGraveyard() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getStoreGraveyardCleanupDelayMinutes() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getStoreGraveyardCleanupSleepIntervalBetweenListFetchMinutes() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getStoreInfoList() - Method in class com.linkedin.venice.controllerapi.MultiStoreInfoResponse
 
getStoreIngestionService() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
getStoreIngestionService() - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
getStoreIngestionService() - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
 
getStoreIngestionService() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getStoreIngestionService() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getStoreIngestionTask(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getStoreIngestionTask(String) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
 
getStoreIngestionTaskBuilder(String) - Static method in class com.linkedin.venice.utils.TestUtils
 
getStoreKeySchemas() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'storeKeySchemas' field.
getStoreLargestUsedVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getStoreLargestUsedVersion(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getStoreMetadata() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getStoreMetadataFetchMode() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getStoreMetadataRepo() - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
getStoreMetadataRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getStoreMetadataSystemStoreEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'storeMetadataSystemStoreEnabled' field.
getStoreMetaKey(Map<String, String>) - Method in enum com.linkedin.venice.system.store.MetaStoreDataType
 
getStoreMetaSystemStoreEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'storeMetaSystemStoreEnabled' field.
getStoreMetaValue(StoreMetaKey) - Method in class com.linkedin.venice.fastclient.meta.DaVinciClientBasedMetadata
Deprecated.
 
getStoreMetaValue(StoreMetaKey) - Method in class com.linkedin.venice.fastclient.meta.ThinClientBasedMetadata
 
getStoreMetaValue(StoreMetaKey) - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getStoreMetaValue(String, StoreMetaKey) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getStoreMetaValue(String, StoreMetaKey) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getStoreMetaValue(String, StoreMetaKey) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
 
getStoreMigration() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getStoreMigrationAllowed() - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
getStoreName() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
getStoreName() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
getStoreName() - Method in class com.linkedin.davinci.config.StoreBackendConfig
 
getStoreName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getStoreName() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
getStoreName() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getStoreName() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
getStoreName() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
getStoreName() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
Returns the Venice store name this class is associated with.
getStoreName() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getStoreName() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
 
getStoreName() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getStoreName() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Gets the value of the 'storeName' field.
getStoreName() - Method in exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
getStoreName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
 
getStoreName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
 
getStoreName() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getStoreName() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
getStoreName() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
getStoreName() - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
getStoreName() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
getStoreName() - Method in exception com.linkedin.venice.hadoop.exceptions.VeniceStoreCreationException
 
getStoreName() - Method in class com.linkedin.venice.listener.request.AdminRequest
 
getStoreName() - Method in class com.linkedin.venice.listener.request.CurrentVersionRequest
 
getStoreName() - Method in class com.linkedin.venice.listener.request.DictionaryFetchRequest
 
getStoreName() - Method in class com.linkedin.venice.listener.request.MetadataFetchRequest
 
getStoreName() - Method in class com.linkedin.venice.listener.request.RouterRequest
 
getStoreName() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
getStoreName() - Method in exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
 
getStoreName() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getStoreName() - Method in class com.linkedin.venice.meta.StoreConfig
 
getStoreName() - Method in class com.linkedin.venice.meta.StoreDataAudit
 
getStoreName() - Method in interface com.linkedin.venice.meta.Version
 
getStoreName() - Method in class com.linkedin.venice.meta.VersionImpl
 
getStoreName() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
getStoreName() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
 
getStoreName() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getStoreName() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getStoreName() - Method in exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
 
getStoreName() - Method in class com.linkedin.venice.schema.SchemaData
 
getStoreName() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Gets the value of the 'storeName' field.
getStoreName() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'storeName' field.
getStoreOrThrow(String) - Method in class com.linkedin.davinci.DaVinciBackend
 
getStoreOrThrow(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getStoreOrThrow(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
Only the zk shared system store can be returned, otherwise this function will throw VeniceNoStoreException.
getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
getStoreOrThrow(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
 
getStorePartitionDescription() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
getStorePath(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getStorePersistenceType() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
getStoreProperties() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'storeProperties' field.
getStoreProperties(String) - Method in class com.linkedin.venice.utils.VeniceProperties
Get store related properties.
getStoreQuotaInBytes() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
getStoreReadThrottler(String) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
getStoreReplicaStatuses() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'storeReplicaStatuses' field.
getStoreRepo() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
getStoreRepo() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
getStoreRepository() - Method in class com.linkedin.davinci.DaVinciBackend
 
getStoreRepository() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
getStoreRepository() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
getStores() - Method in class com.linkedin.venice.controllerapi.MultiStoreResponse
 
getStoresFromZk() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
HelixReadOnlyZKSharedSystemStoreRepository is overriding this function to filter out stores, which are not necessary to put a watch against during CachedReadOnlyStoreRepository.refresh(), and if this logic to refresh the zk store repository gets changed in the future, we need to update HelixReadOnlyZKSharedSystemStoreRepository accordingly.
getStoresFromZk() - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
This function is used to filter out non system stores from the system store cluster, and this is very important since CachedReadOnlyStoreRepository.refresh() is relying on this function to retrieve all the stores in this cluster and put a watch against each znode, and we need to filter out non-system stores to avoid unnecessary zk watches.
getStoresFromZk(Collection<String>) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getStoresInCluster(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
getStoreSizeInBytes() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getStoreSizeInBytes() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
 
getStoreSizeInBytes() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
getStoreSizeInBytes() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngine
 
getStoreSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
getStoreStats(String) - Method in class com.linkedin.venice.stats.AbstractVeniceAggStats
 
getStoreStats(String) - Method in class com.linkedin.venice.stats.AbstractVeniceAggStoreStats
 
getStoreStatues(List<Store>, ResourceAssignment, PushMonitor) - Static method in class com.linkedin.venice.controller.kafka.StoreStatusDecider
Get the statuses of given stores based on the replicas statues in the given assignment.
getStoreStatusMap() - Method in class com.linkedin.venice.controllerapi.MultiStoreStatusResponse
 
getStoresToEnforce() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Gets the value of the 'storesToEnforce' field.
getStoresToEnforce() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Gets the value of the 'storesToEnforce' field.
getStoresToEnforce() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
getStoresToEnforce() - Method in class com.linkedin.venice.persona.Persona
 
getStoresToEnforceAsList() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
getStoreStorageQuota() - Method in class com.linkedin.venice.hadoop.InputStorageQuotaTracker
 
getStoreToEarlyTerminationThresholdMSMap() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getStoreType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Gets the value of the 'storeType' field.
getStoreType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Gets the value of the 'storeType' field.
getStoreUserPartitionMapping() - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
Gets the value of the 'storeUserPartitionMapping' field.
getStoreValueSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'storeValueSchema' field.
getStoreValueSchemaIdsWrittenPerStoreVersion() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'storeValueSchemaIdsWrittenPerStoreVersion' field.
getStoreValueSchemas() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'storeValueSchemas' field.
getStoreVersion() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
 
getStoreVersion() - Method in class com.linkedin.venice.listener.request.AdminRequest
 
getStoreVersion() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
Gets the value of the 'storeVersion' field.
getStoreVersionBuckets() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
getStoreVersionCompressionDictionary(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getStoreVersionCompressionDictionary(String) - Method in interface com.linkedin.davinci.storage.IngestionMetadataRetriever
 
getStoreVersionCompressionDictionary(String) - Method in interface com.linkedin.davinci.storage.StorageMetadataService
Tailored function for retrieving version's compression dictionary.
getStoreVersionName() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
getStoreVersionName() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getStoreVersionState() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Retrieve the store version state from the metadata partition.
getStoreVersionState() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Gets the value of the 'storeVersionState' field.
getStoreVersionState() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'storeVersionState' field.
getStoreVersionState(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
getStoreVersionState(String) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
getStoreVersionState(String) - Method in interface com.linkedin.davinci.storage.StorageMetadataService
Gets the currently-persisted StoreVersionState for this topic.
getStoreVersionState(String) - Method in class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
Gets the currently-persisted StoreVersionState for this topic.
getStoreVersionState(String) - Method in class com.linkedin.venice.offsets.InMemoryStorageMetadataService
 
getStoreVersionStateSyncer() - Method in class com.linkedin.davinci.storage.StorageService
 
getStoreViews() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getStoreWriterBufferMemoryCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getStoreWriterBufferNotifyDelta() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getStoreWriterNumber() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getStoreZkPath(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getStrategies() - Method in class com.linkedin.venice.controllerapi.MigrationPushStrategyResponse
 
getStrategy() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getStrategy() - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
 
getStrategy() - Method in class com.linkedin.venice.pushmonitor.WaitAllPushStatusDecider
 
getStrategy() - Method in class com.linkedin.venice.pushmonitor.WaitNMinusOnePushStatusDecider
 
getStrategyClass() - Method in enum com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategyEnum
 
getStreamingFooterRecord(ComputeResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
 
getStreamingFooterRecord(MultiGetResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
 
getStreamingFooterRecord(ENVELOPE) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
getString(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
getString(String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getString(String, String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getString(String, Supplier<String>) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getStringError() - Method in class com.linkedin.alpini.io.ExternalCommand
Returns the error as a string.
getStringError(String) - Method in class com.linkedin.alpini.io.ExternalCommand
Returns the error as a string.
getStringError(Charset) - Method in class com.linkedin.alpini.io.ExternalCommand
Returns the error as a string.
getStringKeyCharSequenceValueMapFromStringMap(Map<String, String>) - Static method in class com.linkedin.venice.utils.CollectionUtils
 
getStringMap(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
getStringMapFromCharSequenceMap(Map<CharSequence, CharSequence>) - Static method in class com.linkedin.venice.utils.CollectionUtils
 
getStringOutput() - Method in class com.linkedin.alpini.io.ExternalCommand
Returns the output as a string.
getStringOutput(String) - Method in class com.linkedin.alpini.io.ExternalCommand
Returns the output as a string.
getStringOutput(Charset) - Method in class com.linkedin.alpini.io.ExternalCommand
Returns the output as a string.
getStringSet(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
getStringWithAlternative(String, String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getStringWithAlternative(String, String, String) - Method in class com.linkedin.venice.utils.VeniceProperties
 
getStub(ManagedChannel) - Method in class com.linkedin.venice.fastclient.transport.GrpcTransportClient
 
getStuckConsumerDetectionAndRepairRunnable(Map<String, AbstractKafkaConsumerService>, Map<String, StoreIngestionTask>, long, long, long, StuckConsumerRepairStats, Consumer<String>) - Static method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
getStuckConsumerDetectionRepairThresholdSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getStuckConsumerRepairIntervalSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getSubPartition(PubSubTopicPartition, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getSubPartitionId(byte[], PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getSubPartitions(int, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getSubPartitions(Collection<Integer>, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getSubPartitionStatus() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getSubscribePrepLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getSubscribePrepLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getSuccessfulPushDurationInSecs() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
getSuccessMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
getSuccessRequestKeyCountRate() - Method in class com.linkedin.venice.client.stats.BasicClientStats
 
getSum(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
 
getSupersetOrLatestValueSchema() - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
Retrieve the superset schema (if exists) or the latest value schema and return corresponding annotated value schema.
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
Caller shouldn't modify the returned SchemeEntry
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getSupersetOrLatestValueSchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Get the most recent value schema or superset value schema if one exists.
getSupersetOrLatestValueSchemaId() - Method in class com.linkedin.davinci.VersionBackend
 
getSupersetSchema() - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
Retrieve the superset schema (if exists) and return corresponding annotated value schema.
getSupersetSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Gets the value of the 'supersetSchema' field.
getSupersetSchema(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getSupersetSchema(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getSupersetSchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getSupersetSchema(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getSupersetSchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Get the superset value schema for a given store.
getSuperSetSchemaAutoGenerationForReadComputeEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'superSetSchemaAutoGenerationForReadComputeEnabled' field.
getSupersetSchemaFromSchemaResponse(MultiSchemaResponse, int) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
 
getSupersetSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Gets the value of the 'supersetSchemaId' field.
getSuperSetSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaIdResponse
 
getSuperSetSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse
 
getSupposedlyOngoingIncrementalPushVersions(String, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
getSystemSchemaClusterD2ServiceName() - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
getSystemSchemaClusterD2ZkHost() - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
getSystemSchemaClusterName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getSystemSchemaClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getSystemSchemaClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getSystemSchemaClusterName() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getSystemStore() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'systemStore' field.
getSystemStoreAclFromTopicAcl(AclBinding) - Static method in enum com.linkedin.venice.common.VeniceSystemStoreType
AclBinding of system store resource retrieved from authorizer service will not have the system store specific Method types and instead will either be READ or WRITE.
getSystemStoreAclSynchronizationDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getSystemStoreAclSynchronizationDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getSystemStoreName() - Method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
 
getSystemStoreName(String) - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
This function is to compose a system store name according to the current system store type and the regular store name.
getSystemStores() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getSystemStores() - Method in interface com.linkedin.venice.meta.Store
 
getSystemStores() - Method in class com.linkedin.venice.meta.SystemStore
 
getSystemStores() - Method in class com.linkedin.venice.meta.ZKStore
 
getSystemStores() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'systemStores' field.
getSystemStoreType() - Method in class com.linkedin.venice.meta.SerializableSystemStore
 
getSystemStoreType() - Method in class com.linkedin.venice.meta.SystemStore
 
getSystemStoreType(String) - Static method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
getTable(StructType, Transform[], Map<String, String>) - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsSource
 
getTargetedRegions() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'targetedRegions' field.
getTargetFileSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getTargetRegion() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
 
getTargetRegion() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
 
getTargetVersionStates() - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
Gets the value of the 'targetVersionStates' field.
getTaskId() - Method in interface com.linkedin.venice.hadoop.engine.EngineTaskConfigProvider
 
getTaskId() - Method in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
 
getTaskId() - Method in class com.linkedin.venice.hadoop.spark.engine.SparkEngineTaskConfigProvider
 
getTaskId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
getTaskParams() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
 
getTaskResult() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
 
getTasks() - Method in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
getTaskTracker() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
getTaskTracker() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
getTaskTracker() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
getTempDataDirectory() - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
getTempDataDirectory() - Static method in class com.linkedin.venice.utils.Utils
 
getTempDataDirectory(String) - Static method in class com.linkedin.venice.utils.Utils
 
getTerminalStateTopicCheckerDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTerminalStateTopicCheckerDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getTestCallStats() - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
getTestTime50Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 50 percentage time to create an object.
getTestTime95Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 95 percentage time to create an object.
getTestTime99Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the 99 percentage time to create an object.
getTestTimeAvg() - Method in interface com.linkedin.alpini.base.pool.PoolStats.LifeCycleStats
Get the average time to create an object.
getThenReset() - Method in class com.linkedin.alpini.base.concurrency.ComplexAccumulator
Equivalent in effect to ComplexAccumulator.get() followed by ComplexAccumulator.reset().
getThenReset() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
Equivalent in effect to ConcurrentAccumulator.get() followed by ConcurrentAccumulator.reset().
getThenReset() - Method in class com.linkedin.alpini.base.concurrency.ThreadedAccumulator
 
getThinClientForMetaStore() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
getTime() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getTime() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
 
getTime() - Method in class com.linkedin.venice.throttle.EventThrottler
 
getTime() - Method in class com.linkedin.venice.writer.VeniceWriter
 
getTime() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getTimeMillis(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getTimeMillis(CharSequence, long) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
getTimeout() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
getTimeoutProcessor() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
 
getTimeSinceLastStartCall() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
getTimeSinceLastStartCall() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getTimeSinceLastStartCall() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
getTimestamp() - Method in class com.linkedin.alpini.base.misc.RetryCounter
 
getTimestamp() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
getTimestamp() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getTimestamp() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class com.linkedin.venice.participant.protocol.KillPushJob
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class com.linkedin.venice.samza.VeniceObjectWithTimestamp
 
getTimestamp() - Method in class com.linkedin.venice.schema.rmd.v1.ElementTimestampAndIdx
 
getTimestamp() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
Gets the value of the 'timestamp' field.
getTimestamp() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Gets the value of the 'timestamp' field.
getTimestampAfterProduce() - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
getTimestampBeforeProduce() - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
getTimestampMetadataVersionId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'timestampMetadataVersionId' field.
getTimestampMetadataVersionId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Gets the value of the 'timestampMetadataVersionId' field.
getTimestampMetadataVersionId() - Method in interface com.linkedin.venice.meta.Version
Deprecated.
getTimestampMetadataVersionId() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'timestampMetadataVersionId' field.
getTimestampPolicy() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Gets the value of the 'timestampPolicy' field.
getTimestampRegressionDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getTlsConfiguration() - Static method in class com.linkedin.venice.utils.SslUtils
 
getTombstoneCreationDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getTopic() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
getTopic() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getTopic() - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
 
getTopic() - Method in class com.linkedin.venice.listener.request.TopicPartitionIngestionContextRequest
 
getTopic() - Method in class com.linkedin.venice.meta.PartitionAssignment
 
getTopic() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
 
getTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
The topic the record was appended to
getTopic(String) - Method in class com.linkedin.venice.pubsub.PubSubTopicRepository
 
getTopicCleanupDelayFactor() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTopicCleanupDelayFactor() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getTopicCleanupSleepIntervalBetweenTopicListFetchMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTopicCleanupSleepIntervalBetweenTopicListFetchMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Retrieves the configuration of a Kafka topic.
getTopicConfig(PubSubTopic) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Retrieves the configuration of a PubSub topic.
getTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
This operation is a little heavy, since it will pull the configs for all the topics.
getTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
getTopicConfigMaxRetryInMs() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
 
getTopicConfigMaxRetryInMs() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
 
getTopicConfigsResponse() - Method in class com.linkedin.venice.controllerapi.PubSubTopicConfigResponse
 
getTopicConfigWithRetry(PubSubTopic) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
 
getTopicConfigWithRetry(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getTopicConfigWithRetry(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
getTopicCreationThrottlingTimeWindowMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTopicCreationThrottlingTimeWindowMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getTopicDeletionStatusPollIntervalMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTopicDeletionStatusPollIntervalMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getTopicDeletionStatusPollIntervalMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getTopicIngestionStatusMap() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getTopicLatestOffsets(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Get the latest offsets for all partitions of a given topic.
getTopicManager() - Method in interface com.linkedin.venice.controller.Admin
 
getTopicManager() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getTopicManager() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getTopicManager(String) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
The function returns local or remote topic manager.
getTopicManager(String) - Method in interface com.linkedin.venice.controller.Admin
 
getTopicManager(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getTopicManager(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getTopicManager(String) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerRepository
 
getTopicManagerKafkaOperationTimeOutMs() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTopicManagerKafkaOperationTimeOutMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getTopicManagerMetadataFetcherConsumerPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getTopicManagerMetadataFetcherConsumerPoolSize() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTopicManagerMetadataFetcherThreadPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getTopicManagerMetadataFetcherThreadPoolSize() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getTopicManagerRepository() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getTopicMaxLogCompactionLagMs(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getTopicMetadataFetcherConsumerPoolSize() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getTopicMetadataFetcherThreadPoolSize() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getTopicMinLogCompactionLagMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getTopicMinLogCompactionLagMs(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getTopicName() - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
getTopicName() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Gets the value of the 'topicName' field.
getTopicName() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
Gets the value of the 'topicName' field.
getTopicName() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Gets the value of the 'topicName' field.
getTopicName() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getTopicName() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopicPartition
 
getTopicName() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
getTopicName() - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
getTopicName() - Method in class com.linkedin.venice.writer.VeniceWriter
 
getTopicName() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getTopicNameFromClusterName(String) - Static method in class com.linkedin.venice.controller.kafka.AdminTopicUtils
 
getTopicNamesAndConfigsForVersion(int) - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
 
getTopicNamesAndConfigsForVersion(int) - Method in class com.linkedin.venice.views.ChangeCaptureView
 
getTopicNamesAndConfigsForVersion(int) - Method in class com.linkedin.venice.views.VeniceView
Implementations should override to return a map of topicName:topic Configs relevant for topic materialization (things like partition count, RF, etc.) TODO: Come up with list of config names that should be parsed by VeniceAdmin to pass along to TopicManager.
getTopicOffsetCheckIntervalMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
getTopicOffsetCheckIntervalMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
getTopicPartition() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
getTopicPartition() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getTopicPartition() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
Returns the topic and partition for the split
getTopicPartition() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getTopicPartition() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
getTopicPartition() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionInfo
 
getTopicPartition() - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
getTopicPartition(Integer) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
getTopicPartitionCount(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getTopicPartitionEndOffSet(String, PubSubTopic, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getTopicPartitionInfo(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Get information about all partitions for a given topic.
getTopicPartitionIngestionContext() - Method in class com.linkedin.davinci.listener.response.TopicPartitionIngestionContextResponse
 
getTopicPartitionIngestionContext(String, String, Integer) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getTopicPartitionIngestionContext(String, String, Integer) - Method in interface com.linkedin.davinci.storage.IngestionMetadataRetriever
 
getTopicPartitionIngestionStatus(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getTopicPartitionLeaderStatusMap() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
getTopicPartitionOffsetByKafkaURL(CharSequence, PubSubTopicPartition, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getTopicRetention(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Return topic retention time in MS.
getTopicRetention(PubSubTopicConfiguration) - Static method in class com.linkedin.venice.pubsub.manager.TopicManager
 
getTopics() - Method in class com.linkedin.venice.controllerapi.MultiStoreTopicsResponse
 
getTopicsOfOngoingOfflinePushes() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getTopicsOfOngoingOfflinePushes() - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Find all ongoing pushes then return the topics associated to those pushes.
getTopicsOfOngoingOfflinePushes() - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getTopicSwitch() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getTopicSwitch() - Method in class com.linkedin.davinci.kafka.consumer.TopicSwitchWrapper
 
getTopicSwitch() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Gets the value of the 'topicSwitch' field.
getTopicToMonitor() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
getTopLevelColoID() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
getTopLevelFieldTimestamp() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
getToString() - Method in class com.linkedin.venice.client.schema.SchemaAndToString
 
getTotalAcquireRetries() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getTotalAcquireRetries() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getTotalActiveStreamChannels() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getTotalActiveStreamChannels() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getTotalActiveStreams() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getTotalActiveStreams() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getTotalCompressedValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'totalCompressedValueBytes' field.
getTotalCount() - Method in class com.linkedin.alpini.base.misc.CounterQueue
 
getTotalCount() - Method in class com.linkedin.alpini.base.misc.RetryCounter
 
getTotalCount() - Method in class com.linkedin.alpini.base.misc.RetryCountSlidingWindow
 
getTotalCreated() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the total number of pool objects created between the starting of the Pool and the call to getStats().
getTotalCreateErrors() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the total number of lifecycle create errors between the starting of the Pool and the call to getStats().
getTotalDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getTotalDestroyed() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the total number of pool objects destroyed between the starting of the Pool and the call to getStats().
getTotalDestroyErrors() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the total number of lifecycle destroy errors between the starting of the Pool and the call to getStats().
getTotalDiscardedBytes() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalDiscardedBytes() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalEntryCount() - Method in interface com.linkedin.venice.client.store.streaming.VeniceResponseMap
Return the total number of entries, including non-existing keys.
getTotalEntryCount() - Method in class com.linkedin.venice.client.store.streaming.VeniceResponseMapImpl
 
getTotalEstimatedTime() - Method in class com.linkedin.venice.datarecovery.DataRecoveryEstimator
 
getTotalGzipCompressedValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'totalGzipCompressedValueBytes' field.
getTotalGzipCompressedValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getTotalGzipCompressedValueSize() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getTotalGzipCompressedValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getTotalGzipCompressedValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalIncomingDataSizeInBytes() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
getTotalIncomingDataSizeInBytes() - Method in class com.linkedin.venice.hadoop.spark.datawriter.writer.SparkPartitionWriter
 
getTotalIncomingDataSizeInBytes() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
Return the size of serialized key and serialized value in bytes across the entire dataset.
getTotalKeyBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'totalKeyBytes' field.
getTotalKeySize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getTotalKeySize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getTotalKeySize() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getTotalKeySize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getTotalKeySize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalKeySize(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalMemoryUsage() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
 
getTotalMemoryUsage() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
getTotalMemoryUsage() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
getTotalNumberOfRecords() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'totalNumberOfRecords' field.
getTotalPutOrDeleteRecordsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getTotalPutOrDeleteRecordsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getTotalPutOrDeleteRecordsCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getTotalPutOrDeleteRecordsCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalPutOrDeleteRecordsCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalRawValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'totalRawValueBytes' field.
getTotalRemainingMemory() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
 
getTotalRemainingMemory() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
getTotalRemainingMemory() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
getTotalRequestsReceived() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRequestsReceived() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRequestsSent() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRequestsSent() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriedKeys() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriedKeys() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriedOn429() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriedOn429() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetries() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetries() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriesDiscarded() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriesDiscarded() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriesError() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriesError() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriesOn503() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriesOn503() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriesOn503Error() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriesOn503Error() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriesOn503Winner() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriesOn503Winner() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetriesWinner() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
getTotalRetriesWinner() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
 
getTotalRetryCount() - Method in class com.linkedin.alpini.base.misc.CounterQueue
 
getTotalRuntimeNanos() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
getTotalStats() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
getTotalStats() - Method in class com.linkedin.venice.stats.AbstractVeniceAggStats
 
getTotalStats(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
getTotalStoreReadQuota() - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getTotalStoreReadQuota() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
getTotalStoreReadQuota() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
getTotalStoreReadQuota() - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
 
getTotalStoreReadQuota() - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Get total read quota of all stores.
getTotalStreamChannelsReused() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getTotalStreamChannelsReused() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getTotalStreamCreations() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
getTotalStreamCreations() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
getTotalUncompressedValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getTotalUncompressedValueSize() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getTotalUncompressedValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getTotalUncompressedValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getTotalValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getTotalValueSize() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getTotalValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getTotalValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalValueSize(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTotalZstdCompressedValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getTotalZstdCompressedValueSize() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getTotalZstdCompressedValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getTotalZstdWithDictCompressedValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'totalZstdWithDictCompressedValueBytes' field.
getTotalZstdWithDictCompressedValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getTrailerHeaders() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Gets the value of the 'trailerHeaders' field.
getTransformerErrorCount() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getTransformerValueSchema() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getTransientRecord(byte[]) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getTransientRecordMapSize() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getTransportClient() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
getTransportClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
 
getTrustManagerAlgorithm() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getTrustManagers(SSLFactory) - Static method in class com.linkedin.venice.grpc.GrpcSslUtils
 
getTrustManagers(SSLFactory, String) - Static method in class com.linkedin.venice.grpc.GrpcSslUtils
 
getTrustStoreFilePassword() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getTrustStoreFilePassword() - Method in class com.linkedin.venice.security.SSLConfig
 
getTrustStoreFilePath() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getTrustStoreFilePath() - Method in class com.linkedin.venice.security.SSLConfig
 
getTrustStorePassword() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getTrustStorePath() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getTrustStoreType() - Method in class com.linkedin.venice.security.SSLConfig
 
getTrustStoreType() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
getTtlInMilliseconds() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
getType() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
getType() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
getType() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
 
getType() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
getType() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngine
 
getType() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
getType() - Method in class com.linkedin.venice.kafka.validation.checksum.Adler32CheckSum
 
getType() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
getType() - Method in class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
 
getType() - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
 
getType() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
Gets the value of the 'type' field.
getType() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
Gets the type of this result.
getType() - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
getTypeResourceType(String) - Static method in enum com.linkedin.venice.router.api.RouterResourceType
 
getUncompletedPartitions() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
getUncompletedPartitions() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
getUncompletedPartitions(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
getUncompletedPartitions(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
 
getUncompletedPartitions(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
getUncompletedReplicas() - Method in class com.linkedin.venice.meta.UncompletedPartition
 
getUnhealthyInstanceCount() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
 
getUniqueString() - Static method in class com.linkedin.venice.utils.Utils
 
getUniqueString(String) - Static method in class com.linkedin.venice.utils.Utils
 
getUniqueTempPath() - Static method in class com.linkedin.venice.utils.Utils
 
getUniqueTempPath(String) - Static method in class com.linkedin.venice.utils.Utils
 
getUniqueTopicString(String) - Static method in class com.linkedin.venice.utils.TestUtils
 
getUnit() - Method in class com.linkedin.alpini.base.misc.TimeValue
 
getUnknownFields() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
getUnknownFields() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
getUnreachableSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
 
getUnreadyReplicas() - Method in class com.linkedin.venice.controllerapi.NodeReplicasReadinessResponse
 
getUnretrievablePartitions() - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
 
getUnusedSchemaCleanupIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
getUnusedSchemaCleanupIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'unusedSchemaDeletionEnabled' field.
getUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'unusedSchemaDeletionEnabled' field.
getUpcomingAggregates() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
Gets the value of the 'upcomingAggregates' field.
getUpdateClusterConfigQueryParams(CommandLine) - Static method in class com.linkedin.venice.AdminTool
 
getUpdatedConfigsList() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'updatedConfigsList' field.
getUpdatedConfigsList() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getUpdatedResources() - Method in class com.linkedin.venice.helix.ResourceAssignment.ResourceAssignmentChanges
 
getUpdateIgnoredRate() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getUpdateSchema(int) - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
getUpdateSchema(int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getUpdateSchema(int) - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getUpdateSchema(int) - Method in interface com.linkedin.venice.schema.SchemaReader
 
getUpdateSchema(int) - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
getUpdateSchema(Schema) - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
getUpdateSchema(Schema) - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
Returns the Update (Write Compute) schema of the provided Value schema.
getUpdateSchemaEntry(int) - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
getUpdateSchemaEntry(int) - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
Get the latest derived schema of a value schema.
getUpdateSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Update
Gets the value of the 'updateSchemaId' field.
getUpdateValue() - Method in class com.linkedin.venice.kafka.protocol.Update
Gets the value of the 'updateValue' field.
getUpstreamKafkaClusterId() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Gets the value of the 'upstreamKafkaClusterId' field.
getUpstreamKafkaClusterId() - Method in class com.linkedin.venice.writer.LeaderMetadataWrapper
 
getUpstreamOffset() - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
 
getUpstreamOffset() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Gets the value of the 'upstreamOffset' field.
getUpstreamOffset() - Method in class com.linkedin.venice.writer.LeaderMetadataWrapper
 
getUpstreamOffset(String) - Method in class com.linkedin.venice.offsets.OffsetRecord
The caller of this API should be interested in the largest known upstream offset.
getUpstreamOffsetMap() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'upstreamOffsetMap' field.
getUpstreamOffsetWithNoDefault(String) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
getUpstreamVersionTopicOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Gets the value of the 'upstreamVersionTopicOffset' field.
getUri() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
The request URI
getUrl() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
 
getUrl() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
getUrl() - Method in class com.linkedin.venice.meta.Instance
Deprecated.
getUrl() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
getUrl(boolean) - Method in class com.linkedin.venice.meta.Instance
Convenience method for getting a host and port based url.
getUsage() - Method in class com.linkedin.davinci.utils.StoragePartitionDiskUsage
 
getUseInsecureLegacyTlsProtocolBecauseOfBrokenPeersUsingAncientJdk() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
getUserCredentialsFromTokenFile() - Static method in class com.linkedin.venice.hadoop.ssl.UserCredentialsFactory
Get user's credentials from the the Hadoop token file
getUserInputDataFrame() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
Get the data frame based on the user's input data.
getUserInputDataFrame() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.DataWriterSparkJob
 
getUserPartition() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
getUserPartition(int, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getUserPartitionLevelVenicePartitioner(PartitionerConfig) - Static method in class com.linkedin.venice.utils.PartitionUtils
This util method returns a new venice partitioner that works for user-level partition, regardless of the amplification factor in the partitioner config.
getUserPartitions(String) - Method in class com.linkedin.davinci.storage.StorageService
 
getUserPartitions(Collection<Integer>, int) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getUseVersionLevelHybridConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'useVersionLevelHybridConfig' field.
getUseVersionLevelIncrementalPushEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'useVersionLevelIncrementalPushEnabled' field.
getValidAdminProperties(Properties) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
 
getValidateSchemaAndBuildDictionaryOutputDir(String, String, String) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
Creating the output file for ValidateSchemaAndBuildDictMapper to persist data to be read from VPJ driver.
getValidateSchemaAndBuildDictionaryOutputFileName(String) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
 
getValidateSchemaAndBuildDictionaryOutputFileNameNoExtension(String) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
 
getValidateSchemaAndBuildDictMapperOutputReader(String, String) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
getValidConsumerProperties(Properties) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
getValidProducerProperties(Properties) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
getValue() - Method in class com.linkedin.alpini.base.hash.Crc32
 
getValue() - Method in class com.linkedin.alpini.base.hash.Crc32C
 
getValue() - Method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
 
getValue() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
getValue() - Method in enum com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
 
getValue() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
getValue() - Method in enum com.linkedin.davinci.replication.BatchConflictResolutionPolicy
 
getValue() - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
getValue() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
Gets the value of the 'value' field.
getValue() - Method in enum com.linkedin.venice.common.StoreMetadataType
 
getValue() - Method in enum com.linkedin.venice.compression.CompressionStrategy
 
getValue() - Method in enum com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
 
getValue() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
Gets the value of the 'value' field.
getValue() - Method in enum com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
getValue() - Method in enum com.linkedin.venice.controller.kafka.protocol.enums.SchemaType
 
getValue() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Gets the value of the 'value' field.
getValue() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Gets the value of the 'value' field.
getValue() - Method in enum com.linkedin.venice.hadoop.input.kafka.ttl.TTLResolutionPolicy
 
getValue() - Method in enum com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
getValue() - Method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
getValue() - Method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionComponentType
 
getValue() - Method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
getValue() - Method in enum com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
getValue() - Method in enum com.linkedin.venice.kafka.protocol.enums.MessageType
 
getValue() - Method in enum com.linkedin.venice.kafka.validation.checksum.CheckSumType
 
getValue() - Method in enum com.linkedin.venice.kafka.validation.SegmentStatus
 
getValue() - Method in enum com.linkedin.venice.meta.BufferReplayPolicy
 
getValue() - Method in enum com.linkedin.venice.meta.DataReplicationPolicy
 
getValue() - Method in enum com.linkedin.venice.meta.IngestionMetadataUpdateType
 
getValue() - Method in enum com.linkedin.venice.meta.IngestionMode
 
getValue() - Method in enum com.linkedin.venice.meta.ServerAdminAction
 
getValue() - Method in enum com.linkedin.venice.meta.Version.PushType
 
getValue() - Method in enum com.linkedin.venice.participant.protocol.enums.ParticipantMessageType
 
getValue() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
getValue() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
getValue() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
getValue() - Method in enum com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
 
getValue() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Gets the value of the 'value' field.
getValue() - Method in enum com.linkedin.venice.status.PushJobDetailsStatus
 
getValue() - Method in enum com.linkedin.venice.system.store.MetaStoreDataType
 
getValue() - Method in class com.linkedin.venice.utils.KeyAndValueSchemas
 
getValue() - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
getValue() - Method in interface com.linkedin.venice.utils.VeniceEnumValue
 
getValue() - Method in enum com.linkedin.venice.writer.LeaderCompleteState
 
getValueBytes() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
 
getValueBytes(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
Return a serialized output value
getValueBytes(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
 
getValueBytes(Schema, V) - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
Takes a value, serializes it and wrap it in a ByteByffer.
getValueCompressionStrategy() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Gets the value of the 'valueCompressionStrategy' field.
getValueFromCharSequenceMapWithStringKey(Map<CharSequence, CharSequence>, String) - Static method in class com.linkedin.venice.utils.Utils
Given a key with type String and get a value (if there is one) from a map of type Map which has one of key's toString value equals to the given String key.
getValueFullPathForTempSSTFileDir() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
getValueFuture() - Method in class com.linkedin.venice.client.store.transport.TransportClientCallback
 
getValueLen() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
getValueManifest() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
getValueOffset() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
getValueOrDerivedSchemaId(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getValueOrDerivedSchemaID(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
 
getValueOutputSchema() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
 
getValuePayload(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
 
getValuePayload(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
 
getValuePayload(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
getValueRecord() - Method in class com.linkedin.venice.listener.response.StorageResponseObject
 
getValueRecord(ComputeResponseRecordV1, CompressionStrategy) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
 
getValueRecord(MultiGetResponseRecordV1, CompressionStrategy) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
 
getValueRecord(ENVELOPE, CompressionStrategy) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
getValueRocksDBSstFileWriter() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
getValueSchema() - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
 
getValueSchema() - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
getValueSchema() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
 
getValueSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Gets the value of the 'valueSchema' field.
getValueSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Gets the value of the 'valueSchema' field.
getValueSchema() - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
 
getValueSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
Gets the value of the 'valueSchema' field.
getValueSchema(int) - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
Retrieve value schema and annotate its top-level string array and map fields.
getValueSchema(int) - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
getValueSchema(int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getValueSchema(int) - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getValueSchema(int) - Method in class com.linkedin.venice.schema.SchemaData
 
getValueSchema(int) - Method in interface com.linkedin.venice.schema.SchemaReader
 
getValueSchema(int) - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
getValueSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
Route to handle retrieving value schema by id.
getValueSchema(String, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getValueSchema(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
This function is used to retrieve the value schema for the given store and value schema id.
getValueSchema(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
This function is used to retrieve the value schema for the given store and value schema id.
getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
Get value schema for the given store and schema id.
getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getValueSchema(String, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getValueSchema(String, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Get value schema for the given store and value schema id.
getValueSchema(String, String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
getValueSchema(String, String, int) - Method in interface com.linkedin.venice.controller.Admin
 
getValueSchema(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getValueSchema(String, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getValueSchemaFromETLValueSchema(Schema, ETLValueSchemaTransformation) - Static method in class com.linkedin.venice.etl.ETLUtils
Get the store's value schema from it's value schema in the ETL output and the transformation that was applied to construct it.
getValueSchemaId() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
getValueSchemaId() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
 
getValueSchemaId() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
getValueSchemaId() - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
getValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Gets the value of the 'valueSchemaId' field.
getValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Gets the value of the 'valueSchemaId' field.
getValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Gets the value of the 'valueSchemaId' field.
getValueSchemaId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
 
getValueSchemaId() - Method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
 
getValueSchemaId() - Method in class com.linkedin.venice.writer.DeleteMetadata
 
getValueSchemaId(String, String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getValueSchemaId(String, String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getValueSchemaId(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
This function is used to retrieve value schema id for the given store and schema.
getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
This function is used to retrieve value schema id for the given store and schema.
getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
This function is used to retrieve value schema id for the given store and schema.
getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getValueSchemaId(String, String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getValueSchemaId(String, String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Look up the schema id by store name and value schema.
getValueSchemaId(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getValueSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getValueSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getValueSchemaId(Schema) - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
getValueSchemaId(Schema) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getValueSchemaId(Schema) - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
getValueSchemaId(Schema) - Method in interface com.linkedin.venice.schema.SchemaReader
 
getValueSchemaId(Schema) - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
getValueSchemaID() - Method in class com.linkedin.venice.schema.GeneratedSchemaEntry
 
getValueSchemaID() - Method in class com.linkedin.venice.schema.GeneratedSchemaID
 
getValueSchemaID() - Method in class com.linkedin.venice.schema.rmd.RmdVersionId
 
getValueSchemaID(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
Route to handle retrieving schema id by schema.
getValueSchemaID(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
getValueSchemaInternally(String, int) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getValueSchemaInternally(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getValueSchemaMap() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
Gets the value of the 'valueSchemaMap' field.
getValueSchemaMap() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
Gets the value of the 'valueSchemaMap' field.
getValueSchemaPath() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
 
getValueSchemas() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'valueSchemas' field.
getValueSchemas() - Method in class com.linkedin.venice.schema.SchemaData
 
getValueSchemas(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
getValueSchemas(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
getValueSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
This function is used to retrieve all the value schemas for the given store.
getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
This function is used to retrieve all the value schemas for the given store.
getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
This function is used to retrieve all the value schemas for the given store.
getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
getValueSchemas(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
getValueSchemas(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Get all the value schemas for the given store.
getValueSchemas(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
getValueSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getValueSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getValueSerializer() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
 
getValueSerializer() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getValueSize() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getValueSizeList() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
getValueType() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Gets the value of the 'valueType' field.
getValueUnion() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
getVariance() - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
getVeniceAdminStats() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
getVeniceCache() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
getVeniceClientRequest() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
getVeniceCluster(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
getVeniceCluster(String) - Method in interface com.linkedin.venice.meta.ClusterInfoProvider
Get the associated Venice cluster name given a Venice store name.
getVeniceCluster(String) - Method in class com.linkedin.venice.meta.StaticClusterInfoProvider
 
getVeniceClusterConfig() - Method in class com.linkedin.davinci.config.VeniceConfigLoader
 
getVeniceClusterNameFromPartitionName(String) - Static method in class com.linkedin.venice.controller.VeniceControllerStateModel
Get the regular Venice cluster name after removing the suffix PARTITION_SUFFIX.
getVeniceConfigLoader() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
getVeniceConfigLoader() - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
 
getVeniceConfigLoader() - Method in class com.linkedin.venice.server.VeniceServerContext
 
getVeniceControllerService() - Method in class com.linkedin.venice.controller.VeniceController
 
getVeniceDiscoveryUrl() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getVeniceHelixAdmin() - Method in class com.linkedin.venice.controller.VeniceControllerService
 
getVeniceHelixAdmin() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getVeniceLocalSslFactory() - Static method in class com.linkedin.venice.utils.SslUtils
This function should be used in test cases only.
getVeniceLocalSslProperties() - Static method in class com.linkedin.venice.utils.SslUtils
This function should be used in test cases only.
getVeniceOfflinePushMonitorAccessor() - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
getVenicePartitioner(PartitionerConfig) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getVenicePartitioner(VeniceProperties) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getVenicePartitioner(String, int, VeniceProperties) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getVenicePartitioner(String, int, VeniceProperties, Schema) - Static method in class com.linkedin.venice.utils.PartitionUtils
 
getVeniceProps(JobConf) - Static method in class com.linkedin.venice.hadoop.utils.HadoopUtils
 
getVenicePushStatus() - Method in class com.linkedin.venice.routerapi.ReplicaState
 
getVeniceRouterUrl() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getVeniceServerConfig() - Method in class com.linkedin.davinci.config.VeniceConfigLoader
 
getVeniceServerResponseBuilder() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
getVeniceStore() - Method in class com.linkedin.venice.meta.SerializableSystemStore
 
getVeniceStore() - Method in class com.linkedin.venice.meta.SystemStore
 
getVeniceURL() - Method in class com.linkedin.venice.client.store.ClientConfig
 
getVeniceVersionFromClassPath() - Static method in class com.linkedin.venice.utils.Utils
This might not work when application is running inside application server like Jetty
getVeniceView(String, Properties, Store, Map<String, String>) - Static method in class com.linkedin.venice.views.ViewUtils
 
getVeniceViewWriter(String, VeniceConfigLoader, Store, Schema, Map<String, String>) - Static method in class com.linkedin.davinci.store.view.ViewWriterUtils
 
getVeniceViewWriterFactory() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getVeniceWriter() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getVeniceWriter(VersionCreationResponse) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
This method is overridden and not used by LinkedIn internally.
getVeniceWriter(VersionCreationResponse, Properties) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
Please don't remove this method since it is still being used by LinkedIn internally.
getVeniceWriter(String, PartitionerConfig, Properties, int) - Method in class com.linkedin.venice.hadoop.heartbeat.DefaultPushJobHeartbeatSenderFactory
 
getVeniceWriterFactory() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getVeniceWriterFactory() - Method in interface com.linkedin.venice.controller.Admin
 
getVeniceWriterFactory() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getVeniceWriterFactory() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
getVeniceWriterFactory(Properties, PubSubProducerAdapterFactory) - Static method in class com.linkedin.venice.utils.TestUtils
 
getVersion() - Method in class com.linkedin.davinci.VersionBackend
 
getVersion() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
getVersion() - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
 
getVersion() - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
getVersion() - Method in class com.linkedin.venice.controllerapi.routes.PushJobStatusUploadResponse
 
getVersion() - Method in class com.linkedin.venice.controllerapi.VersionResponse
 
getVersion() - Method in exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
 
getVersion() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
getVersion() - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
Gets the value of the 'version' field.
getVersion() - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
Gets the value of the 'version' field.
getVersion() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
Gets the value of the 'version' field.
getVersion(int) - Method in class com.linkedin.venice.meta.AbstractStore
 
getVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getVersion(int) - Method in interface com.linkedin.venice.meta.Store
 
getVersion(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
getVersion(String, BasicFullHttpRequest) - Method in class com.linkedin.venice.router.api.VeniceVersionFinder
 
getVersionCompressionStrategy(int) - Method in class com.linkedin.venice.meta.AbstractStore
 
getVersionCompressionStrategy(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getVersionCompressionStrategy(int) - Method in interface com.linkedin.venice.meta.Store
 
getVersionCompressor(PubSubTopicPartition) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
getVersionedDIVStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getVersionedDIVStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getVersionedStorageIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
getVersionIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getVersionMetadata() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'versionMetadata' field.
getVersionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'versionNum' field.
getVersionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
Gets the value of the 'versionNum' field.
getVersionNumber() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getVersionNumber() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Gets the value of the 'versionNumber' field.
getVersionNumber() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
getVersionNumber() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
Gets the value of the 'versionNumber' field.
getVersions() - Method in class com.linkedin.venice.controllerapi.MultiVersionResponse
 
getVersions() - Method in class com.linkedin.venice.meta.AbstractStore
 
getVersions() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getVersions() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
getVersions() - Method in interface com.linkedin.venice.meta.Store
 
getVersions() - Method in class com.linkedin.venice.meta.StoreInfo
List of available versions for this store
getVersions() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
getVersions() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
getVersions() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Gets the value of the 'versions' field.
getVersions() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'versions' field.
getVersions() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Gets the value of the 'versions' field.
getVersionSpecificCompressor(String) - Method in class com.linkedin.venice.compression.CompressorFactory
 
getVersionStateDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
 
getVersionStateDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
 
getVersionStatus(int) - Method in class com.linkedin.venice.meta.AbstractStore
 
getVersionStatus(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getVersionStatus(int) - Method in interface com.linkedin.venice.meta.Store
 
getVersionStatus(String, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
getVersionStatusFromInt(int) - Static method in enum com.linkedin.venice.meta.VersionStatus
 
getVersionStatusMap() - Method in class com.linkedin.venice.controllerapi.MultiVersionStatusResponse
 
getVersionSwapDeferred() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Gets the value of the 'versionSwapDeferred' field.
getVersionSwapDetectionIntervalTimeInMs() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getVersionTopic() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getVersionTopic() - Method in class com.linkedin.venice.listener.request.TopicPartitionIngestionContextRequest
 
getVersionTopicEndOffsetRewindCount() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getViabilityResult() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
getViewClassName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
Gets the value of the 'viewClassName' field.
getViewClassName() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getViewClassName() - Method in class com.linkedin.venice.meta.ReadOnlyViewConfig
 
getViewClassName() - Method in interface com.linkedin.venice.meta.ViewConfig
 
getViewClassName() - Method in class com.linkedin.venice.meta.ViewConfigImpl
 
getViewClassName() - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
Gets the value of the 'viewClassName' field.
getViewClassParams() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getViewConfigs() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
getViewConfigs() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
getViewConfigs() - Method in interface com.linkedin.venice.meta.Store
 
getViewConfigs() - Method in class com.linkedin.venice.meta.StoreInfo
 
getViewConfigs() - Method in class com.linkedin.venice.meta.SystemStore
 
getViewConfigs() - Method in interface com.linkedin.venice.meta.Version
 
getViewConfigs() - Method in class com.linkedin.venice.meta.VersionImpl
 
getViewConfigs() - Method in class com.linkedin.venice.meta.ZKStore
 
getViewName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
getViewName() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getViewParameters() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
Gets the value of the 'viewParameters' field.
getViewParameters() - Method in class com.linkedin.venice.meta.ReadOnlyViewConfig
 
getViewParameters() - Method in interface com.linkedin.venice.meta.ViewConfig
 
getViewParameters() - Method in class com.linkedin.venice.meta.ViewConfigImpl
 
getViewParameters() - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
Gets the value of the 'viewParameters' field.
getViews() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'views' field.
getViews() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'views' field.
getViews() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Gets the value of the 'views' field.
getVsonDeserializer(Schema, Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
getVsonFileHeader(FileSystem, Path, boolean) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
getVsonSerializer(Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
getVsonStoreList() - Method in class com.linkedin.venice.client.VeniceStoreClientGlobalConfig
 
getWaiters15min() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getWaiters1min() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getWaiters5min() - Method in interface com.linkedin.alpini.base.pool.PoolStats
 
getWaitingThreads(Condition) - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
Returns a collection containing those threads that may be waiting on the given condition associated with the write lock.
getWaitTime50Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the 50 percentage wait time to get a pooled object.
getWaitTime95Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the 95 percentage wait time to get a pooled object.
getWaitTime99Pct() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the 99 percentage wait time to get a pooled object.
getWaitTimeAvg() - Method in interface com.linkedin.alpini.base.pool.PoolStats
Get the average wait time to get a pooled object.
getWarmUpInstancesFutures() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
getWithSchemaId(AbstractStorageEngine, int, ByteBuffer, boolean, T, BinaryDecoder, StoreDeserializerCache<T>, VeniceCompressor, ChunkedValueManifestContainer) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
 
getWorkingDirectory() - Method in class com.linkedin.alpini.io.ExternalCommand
 
getWorkingInstances() - Method in class com.linkedin.venice.meta.Partition
 
getWorkingInstances(String, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
Get instances from local memory.
getWorkingInstances(String, int) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
Query instances that are online (in leader or follower state), but not necessarily ready to serve yet.
getWriteAclAuthorizationFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
 
getWriteAclAuthorizationFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
getWriteAclAuthorizationFailureCount() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
getWriteAclAuthorizationFailureCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
getWriteAclAuthorizationFailureCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getWriteAclAuthorizationFailureCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
getWriteBufferManager() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
getWriteComputationEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Gets the value of the 'writeComputationEnabled' field.
getWriteComputationEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
getWriteComputationEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Gets the value of the 'writeComputationEnabled' field.
getWriteComputationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Gets the value of the 'writeComputationEnabled' field.
getWriteComputeErrorCode() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
getWriteComputeErrorCode() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
getWriteComputeErrorCode() - Method in class com.linkedin.davinci.stats.IngestionStats
 
getWriteComputeSerializer() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
getWriteQuotaBytesPerSecond() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
getWriter() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
Gets the writer schema that was validated.
getWriterClassName() - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
 
getWriterClassName() - Method in class com.linkedin.venice.views.ChangeCaptureView
 
getWriterClassName() - Method in class com.linkedin.venice.views.VeniceView
Implementations should return the fully specified class name for the component VeniceViewWriter implementation.
getWriterConfig() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
getWriteTimeoutSeconds() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
getWriteTimeoutSeconds() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
getX509Certificate(Certificate) - Static method in class com.linkedin.venice.utils.SslUtils
 
getZkAddress() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
getZkAddress() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
getZkAddress() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
getZkAnnouncers() - Method in class com.linkedin.venice.d2.D2Server
 
getZkAnnouncers() - Method in class com.linkedin.venice.d2.D2ServerManager
 
getZkAnnouncersWithoutStartCheck() - Method in class com.linkedin.venice.d2.D2ServerManager
 
getZkClient() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
getZkClient() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
getZkConnection() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
getZkConnectString() - Method in class com.linkedin.venice.d2.D2ServerManager
 
getZkSharedStore() - Method in class com.linkedin.venice.meta.SerializableSystemStore
 
getZkSharedStore() - Method in class com.linkedin.venice.meta.SystemStore
 
getZkSharedStoreName() - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
getZkSharedStoreNameInCluster(String) - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
getZookeeperAddress() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
 
getZstdDictionary() - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
Gets the value of the 'zstdDictionary' field.
getZstdDictTrainer() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
 
globalShutdown() - Static method in class com.linkedin.alpini.base.registry.ResourceRegistry
Starts shutdown for all ResourceRegistry instances.
GRAVEYARD_CLUSTERS - com.linkedin.venice.Arg
 
GREEDY_ROUTING - com.linkedin.venice.router.api.VeniceMultiKeyRoutingStrategy
 
GROUP_BY_GREEDY_HOST - Static variable in class com.linkedin.alpini.router.api.ScatterGatherMode
Sends request for minimal group of hosts.
GROUP_BY_PARTITION - Static variable in class com.linkedin.alpini.router.api.ScatterGatherMode
One request per partition.
GROUP_BY_PRIMARY_HOST - Static variable in class com.linkedin.alpini.router.api.ScatterGatherMode
Sends request for first host for each partition in request, grouped by host
GROUP_BY_PRIMARY_HOST_ROUTING - com.linkedin.venice.router.api.VeniceMultiKeyRoutingStrategy
 
GROUP_FIELD_NAME_IN_DOMAIN - Static variable in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
GroupAndCounterNames(String, String) - Constructor for class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper.GroupAndCounterNames
 
GRPC_READ_SERVER_PORT - Static variable in class com.linkedin.venice.ConfigKeys
 
GRPC_SERVER_ACL_APPROVED_ATTRIBUTE_KEY - Static variable in class com.linkedin.venice.listener.ServerAclHandler
 
GRPC_SERVER_WORKER_THREAD_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
 
GrpcClientConfig - Class in com.linkedin.venice.fastclient
 
GrpcClientConfig(GrpcClientConfig.Builder) - Constructor for class com.linkedin.venice.fastclient.GrpcClientConfig
 
GrpcClientConfig.Builder - Class in com.linkedin.venice.fastclient
 
GrpcErrorCodes - Class in com.linkedin.venice.grpc
We want to define our own error codes/messages for when we receive any sort of exception or error when processing a gRPC request within the gRPC handler pipeline to remain flexible and not bound to the gRPC error codes.
GrpcErrorCodes() - Constructor for class com.linkedin.venice.grpc.GrpcErrorCodes
 
grpcGetRouterRequest(VeniceClientRequest) - Static method in class com.linkedin.venice.listener.request.GetRouterRequest
 
GrpcOutboundResponseHandler - Class in com.linkedin.venice.listener.grpc.handlers
 
GrpcOutboundResponseHandler() - Constructor for class com.linkedin.venice.listener.grpc.handlers.GrpcOutboundResponseHandler
 
GrpcOutboundStatsHandler - Class in com.linkedin.venice.listener.grpc.handlers
 
GrpcOutboundStatsHandler() - Constructor for class com.linkedin.venice.listener.grpc.handlers.GrpcOutboundStatsHandler
 
GrpcReadQuotaEnforcementHandler - Class in com.linkedin.venice.listener.grpc.handlers
 
GrpcReadQuotaEnforcementHandler(ReadQuotaEnforcementHandler) - Constructor for class com.linkedin.venice.listener.grpc.handlers.GrpcReadQuotaEnforcementHandler
 
GrpcRequestContext - Class in com.linkedin.venice.listener.grpc
We need to keep track of each request as it goes through the pipeline so that we can record the necessary metrics and separate different parts of the logic for the response.
GrpcRequestContext(VeniceClientRequest, VeniceServerResponse.Builder, StreamObserver<VeniceServerResponse>) - Constructor for class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
GrpcRouterRequestHandler - Class in com.linkedin.venice.listener.grpc.handlers
 
GrpcRouterRequestHandler() - Constructor for class com.linkedin.venice.listener.grpc.handlers.GrpcRouterRequestHandler
 
GrpcSslUtils - Class in com.linkedin.venice.grpc
 
GrpcSslUtils() - Constructor for class com.linkedin.venice.grpc.GrpcSslUtils
 
GrpcStatsHandler - Class in com.linkedin.venice.listener.grpc.handlers
 
GrpcStatsHandler(StatsHandler) - Constructor for class com.linkedin.venice.listener.grpc.handlers.GrpcStatsHandler
 
GrpcStorageReadRequestHandler - Class in com.linkedin.venice.listener.grpc.handlers
 
GrpcStorageReadRequestHandler(StorageReadRequestHandler) - Constructor for class com.linkedin.venice.listener.grpc.handlers.GrpcStorageReadRequestHandler
 
GrpcTransportClient - Class in com.linkedin.venice.fastclient.transport
 
GrpcTransportClient(GrpcClientConfig) - Constructor for class com.linkedin.venice.fastclient.transport.GrpcTransportClient
 
GUID - Class in com.linkedin.venice.kafka.protocol
 
GUID() - Constructor for class com.linkedin.venice.kafka.protocol.GUID
 
GUID(byte[]) - Constructor for class com.linkedin.venice.kafka.protocol.GUID
 
GUID_GENERATOR_IMPLEMENTATION - Static variable in class com.linkedin.venice.guid.GuidUtils
 
GUID_SIZE_IN_BYTES - Static variable in class com.linkedin.venice.guid.GuidUtils
 
guidBasedDummyPushId() - Static method in interface com.linkedin.venice.meta.Version
 
GuidUtils - Class in com.linkedin.venice.guid
Utility class for generating GUIDs.
GuidUtils() - Constructor for class com.linkedin.venice.guid.GuidUtils
 
GZIP - com.linkedin.venice.compression.CompressionStrategy
 
GZIP - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
gzipCompressedValueSizeCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
GzipCompressor - Class in com.linkedin.venice.compression
 
GzipCompressor() - Constructor for class com.linkedin.venice.compression.GzipCompressor
 

H

HADAMARD_PRODUCT - com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
 
HADAMARD_PRODUCT_RESULT_SCHEMA - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
HADAMARD_PRODUCT_SPEC - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
hadamardProduct(String, List<Float>, String) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
hadamardProduct(String, List<Float>, String) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Setup hadamard-product operation; if this api is invoked, use version 2 in the compute request version header.
hadamardProduct(List<Float>, List<Float>) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
HadamardProduct - Class in com.linkedin.venice.compute.protocol.request
 
HadamardProduct() - Constructor for class com.linkedin.venice.compute.protocol.request.HadamardProduct
Default constructor.
HadamardProduct(CharSequence, List<Float>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.HadamardProduct
All-args constructor.
HadamardProductOperator - Class in com.linkedin.venice.compute
 
HadamardProductOperator() - Constructor for class com.linkedin.venice.compute.HadamardProductOperator
 
hadamardProductParam - Variable in class com.linkedin.venice.compute.protocol.request.HadamardProduct
The passed feature vector, which will be used to execute hadamard-product calculation against the field in the original value record
HADOOP_PREFIX - Static variable in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
HADOOP_VALIDATE_SCHEMA_AND_BUILD_DICT_PREFIX - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
HadoopJobClientProvider - Interface in com.linkedin.venice.hadoop.mapreduce.engine
 
HadoopUtils - Class in com.linkedin.venice.hadoop.utils
Hadoop-specific utils.
handle(BiFunction<? super T, Throwable, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
handle(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
handle(ExecutionAttemptedEvent<?>) - Method in interface com.linkedin.venice.utils.RetryUtils.IntermediateFailureHandler
 
handle(Request, Response) - Method in class com.linkedin.venice.controller.server.VeniceRouteHandler
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
handleAsync(BiFunction<? super V, Throwable, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
handleAsync(BiFunction<? super V, Throwable, ? extends U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
handleCallbackForEmptyKeySet(Collection<?>, StreamingCallback) - Static method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
handleChildChange(String, List<String>) - Method in class com.linkedin.venice.helix.HelixLiveInstanceMonitor
 
handleChildChange(String, List<String>) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository.StoreConfigAddedOrDeletedChangedListener
 
handleChildChange(String, List<String>) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
Once a router instance is added/remove from cluster, its ephemeral zk node will be added/removed, then this handler will be executed to process the event.
handleCompletedPush(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
handleControlMessage(ControlMessage, PubSubTopicPartition, String, byte[], long) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
Handle control message from the given topic.
handleDataChange(String, Object) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository.StoreConfigChangedListener
 
handleDataChange(String, Object) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
Once router cluster config is changed(Both cluster level or router level config is changed), its persistent zk node's data will be changed, then this handler will be executed to process the event.
handleDataDeleted(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository.StoreConfigChangedListener
 
handleDataDeleted(String) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
handleDeletedInstances(Set<Instance>) - Method in interface com.linkedin.venice.meta.LiveInstanceChangedListener
 
handleDeleteList(long, int, CollectionRmdTimestamp<Object>, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
handleDeleteList(long, int, CollectionRmdTimestamp, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.SortBasedCollectionFieldOpHandler
 
handleDeleteMap(long, int, CollectionRmdTimestamp<String>, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
handleDeleteMap(long, int, CollectionRmdTimestamp<String>, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.SortBasedCollectionFieldOpHandler
 
handleError(Throwable, Request, Response) - Static method in class com.linkedin.venice.controller.server.AdminSparkServer
 
handleError(Throwable, Request, Response, boolean) - Static method in class com.linkedin.venice.controller.server.AdminSparkServer
 
handleErrorPush(String, ExecutionStatusWithDetails) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
handleMessage(KillOfflinePushMessage) - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
handleMessage(T) - Method in interface com.linkedin.venice.status.StatusMessageHandler
 
handleModifyList(long, CollectionRmdTimestamp<Object>, GenericRecord, Schema.Field, List<Object>, List<Object>) - Method in class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
handleModifyList(long, CollectionRmdTimestamp<Object>, GenericRecord, Schema.Field, List<Object>, List<Object>) - Method in class com.linkedin.davinci.schema.merge.SortBasedCollectionFieldOpHandler
 
handleModifyMap(long, CollectionRmdTimestamp<String>, GenericRecord, Schema.Field, Map<String, Object>, List<String>) - Method in class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
handleModifyMap(long, CollectionRmdTimestamp<String>, GenericRecord, Schema.Field, Map<String, Object>, List<String>) - Method in class com.linkedin.davinci.schema.merge.SortBasedCollectionFieldOpHandler
 
handleMultiGetRequest(MultiGetRouterRequestWrapper) - Method in class com.linkedin.venice.listener.StorageReadRequestHandler
 
handleNewInstances(Set<Instance>) - Method in interface com.linkedin.venice.meta.LiveInstanceChangedListener
 
handleNewSession(String) - Method in class com.linkedin.venice.helix.CachedResourceZkStateListener
 
handleNewSession(String) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
handleNewSession(String) - Method in class com.linkedin.venice.stats.ZkClientStatusStats
 
handleOversizedMessage(ChannelHandlerContext, HttpMessage) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpObjectAggregator
 
handleOversizedMessage(ChannelHandlerContext, HttpMessage) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
handleOversizedMessage(ChannelHandlerContext, HttpMessage) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
handleOversizedMessage(ChannelHandlerContext, S) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Invoked when an incoming request exceeds the maximum content length.
handlePutList(long, int, List<Object>, CollectionRmdTimestamp<Object>, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
handlePutList(long, int, List<Object>, CollectionRmdTimestamp<Object>, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.SortBasedCollectionFieldOpHandler
 
handlePutMap(long, int, IndexedHashMap<String, Object>, CollectionRmdTimestamp<String>, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.CollectionFieldOperationHandler
 
handlePutMap(long, int, IndexedHashMap<String, Object>, CollectionRmdTimestamp<String>, GenericRecord, Schema.Field) - Method in class com.linkedin.davinci.schema.merge.SortBasedCollectionFieldOpHandler
 
handler() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Returns the ChannelPoolHandler that will be notified for the different pool actions.
handler() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Returns the ChannelPoolHandler that will be notified for the different pool actions.
handler() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
handler() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
handler() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
handler() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
Returns the ChannelPoolHandler that will be notified for the different pool actions.
handler(CHC, BHS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
handler(ChannelHandler) - Method in class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
the ChannelHandler to use for serving the requests.
handler(ChannelHandlerContext, FullHttpRequest) - Method in interface com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler.RequestHandler
 
handler(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
handlerAdded(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
If override this method ensure you call super!
handlerAdded(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
handlerAdded(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
handlerAdded(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.ssl.FusedSslHandler
 
handlerAdded(ChannelHandlerContext) - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.EspressoMessageAggregator
 
handlerAdded(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.ActiveStreamsCountHandler
 
handlerAdded0(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
handleRequest(String, Map<String, String>, byte[], boolean) - Method in class com.linkedin.venice.fastclient.transport.GrpcTransportClient
 
handleResourceNoBucket(String) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
This method and the expiring set noBucketStores is only used to throttle the logging of such event
handleRouterCountChanged(int) - Method in interface com.linkedin.venice.meta.RoutersClusterManager.RouterCountChangedListener
 
handleRouterCountChanged(int) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
handlerRemoved(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
handlerRemoved(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
If override this method ensure you call super!
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.codec.EspressoMessageAggregator
 
handlerRemoved(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.ActiveStreamsCountHandler
 
handlerRemoved0(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
handleServerOverCapacity(ChannelHandlerContext, GrpcRequestContext, String, int, boolean) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
handleServerPushStatusUpdate(String, ExecutionStatus, String) - Method in class com.linkedin.venice.pushmonitor.PushStatusCollector
 
handleSessionEstablishmentError(Throwable) - Method in class com.linkedin.venice.helix.CachedResourceZkStateListener
 
handleSessionEstablishmentError(Throwable) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
handleSessionEstablishmentError(Throwable) - Method in class com.linkedin.venice.stats.ZkClientStatusStats
 
handleSingleGetRequest(GetRouterRequest) - Method in class com.linkedin.venice.listener.StorageReadRequestHandler
 
handleStateChanged(Watcher.Event.KeeperState) - Method in class com.linkedin.venice.helix.CachedResourceZkStateListener
Once the state of zk connection is changed, this function will be called.
handleStateChanged(Watcher.Event.KeeperState) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
handleStateChanged(Watcher.Event.KeeperState) - Method in class com.linkedin.venice.stats.ZkClientStatusStats
 
handleStoreChanged(StoreBackend) - Method in class com.linkedin.davinci.DaVinciBackend
 
handleStoreChanged(Store) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
handleStoreChanged(Store) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
handleStoreChanged(Store) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatVersionedStats
 
handleStoreChanged(Store) - Method in class com.linkedin.venice.acl.AclCreationDeletionListener
 
handleStoreChanged(Store) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository.StoreChangeListener
 
handleStoreChanged(Store) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
handleStoreChanged(Store) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter.VeniceStoreDataChangedListener
Notify the store change and maybe the corresponding system store change.
handleStoreChanged(Store) - Method in class com.linkedin.venice.helix.StoragePersonaRepository.StoragePersonaStoreDataListener
Currently, changing the size of a store while it is part of a persona is undefined behavior.
handleStoreChanged(Store) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
This is where we add new TokenBucket for new store version and remove irrelevant ones.
handleStoreChanged(Store) - Method in interface com.linkedin.venice.meta.StoreDataChangedListener
 
handleStoreChanged(Store) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
handleStoreChanged(Store) - Method in class com.linkedin.venice.stats.AggServerQuotaTokenBucketStats
 
handleStoreCreated(Store) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
handleStoreCreated(Store) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
handleStoreCreated(Store) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatVersionedStats
 
handleStoreCreated(Store) - Method in class com.linkedin.venice.acl.AclCreationDeletionListener
 
handleStoreCreated(Store) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository.StoreChangeListener
 
handleStoreCreated(Store) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
Do nothing here, since we want to warm up local cache gradually.
handleStoreCreated(Store) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter.VeniceStoreDataChangedListener
Notify the store creation and maybe the corresponding system store creation.
handleStoreCreated(Store) - Method in class com.linkedin.venice.helix.StoragePersonaRepository.StoragePersonaStoreDataListener
Currently, specifying a persona that a store should be added to is not supported.
handleStoreCreated(Store) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
handleStoreCreated(Store) - Method in interface com.linkedin.venice.meta.StoreDataChangedListener
Do NOT try to acquire the lock of store repository again in the implementation, otherwise a dead lock issue will happen.
handleStoreCreated(Store) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
handleStoreCreated(Store) - Method in class com.linkedin.venice.stats.AggServerQuotaTokenBucketStats
 
handleStoreDeleted(Store) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter.VeniceStoreDataChangedListener
Notify the store deletion and maybe the corresponding system store deletion.
handleStoreDeleted(Store) - Method in interface com.linkedin.venice.meta.StoreDataChangedListener
 
handleStoreDeleted(String) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
handleStoreDeleted(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
handleStoreDeleted(String) - Method in class com.linkedin.venice.acl.AclCreationDeletionListener
 
handleStoreDeleted(String) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository.StoreChangeListener
 
handleStoreDeleted(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
For store deletion, we need to delete the local cache entry right way, otherwise the local cache may contain the stale entries for store-delete-and-add scenario.
handleStoreDeleted(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository.StoragePersonaStoreDataListener
This function removes the given store (if it exists) from any existing personas, both in the cache and in ZK, and then removes the mapping from the store to the personas.
handleStoreDeleted(String) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
handleStoreDeleted(String) - Method in interface com.linkedin.venice.meta.StoreDataChangedListener
 
handleStoreDeleted(String) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
handleStoreDeleted(String) - Method in class com.linkedin.venice.stats.AbstractVeniceAggStoreStats
 
handleStoreDeleted(String) - Method in class com.linkedin.venice.stats.AggServerQuotaTokenBucketStats
 
handleStoreExceptionInternally(Throwable) - Static method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
handleStoreListChanged(List<String>) - Method in interface com.linkedin.venice.meta.StoreListChangedListener
 
handleTerminalOfflinePushUpdate(OfflinePushStatus, ExecutionStatusWithDetails) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
This method will unsubscribe external view changes and is intended to be called when the statues are terminable.
handleTooManyRequests(ChannelHandlerContext, RouterRequest, GrpcRequestContext, Store, int, boolean) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
handleUnresolvedUnion(Throwable) - Static method in class com.linkedin.venice.serializer.UnresolvedUnionUtil
 
handleVersionSwapControlMessage(ControlMessage, PubSubTopicPartition, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
HANDSHAKE_TIMEOUT_MILLIS - Static variable in interface com.linkedin.alpini.router.impl.Router.Builder
 
handshakeConnectionTimeoutMillis(long) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
handshakeTimeout(long, TimeUnit) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
handshakeTimeout(long, TimeUnit) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
hasAccess(X509Certificate, String, String) - Method in interface com.linkedin.venice.acl.AccessController
Check if client has permission to access a particular resource.
hasAccess(X509Certificate, String, String) - Method in interface com.linkedin.venice.acl.DynamicAccessController
Check if client has permission to access a particular resource.
hasAccess(X509Certificate, String, String) - Method in interface com.linkedin.venice.acl.StaticAccessController
Check if client has permission to access a particular resource.
hasAccessToAdminOperation(X509Certificate, String) - Method in interface com.linkedin.venice.acl.AccessController
Check if client has permission to execute a particular admin operation.
hasAccessToStore(Request) - Method in class com.linkedin.venice.controller.server.AbstractRoute
Check whether the user has "GET" method access to the related store resource.
hasAccessToTopic(X509Certificate, String, String) - Method in interface com.linkedin.venice.acl.AccessController
Check if client has permission to access a particular topic resource.
hasAcl(String) - Method in interface com.linkedin.venice.acl.DynamicAccessController
Check if ACL exists for a particular resource.
hasAnyPartitionConsumptionState(Predicate<PartitionConsumptionState>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
hasAnySubscription() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
hasAnySubscription() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
hasAnySubscription() - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Checks if the consumer has any active topic-partition subscriptions.
hasAnySubscription() - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
hasAnySubscriptionFor(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
hasAnySubscriptionFor(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
hasAnySubscriptionFor(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
hasAttr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
Returns true if and only if the given Attribute exists in this AttributeMap.
hasAttr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
Returns true if and only if the given Attribute exists in this AttributeMap.
hasAttr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpResponse
Returns true if and only if the given Attribute exists in this AttributeMap.
hasConsumerAssignedFor(String, PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
hasCorrespondingUpstreamMessage() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
Some bookkeeping operations are intended to be performed only on messages produced by the leader which have a directly corresponding upstream message, and should be skipped for messages that are generated by the leader in the absence of a directly corresponding upstream.
hasDocFieldChange(Schema, Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Given s1 and s2 returned SchemaEntry#equals(s1,s2) true, verify they have doc field change.
hasEnoughNodesToStartPush(String, int, ResourceAssignment, Optional<String>) - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
 
hasEnoughReplicasForOnePartition(int, int) - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
 
hasEnoughReplicasForOnePartition(int, int) - Method in class com.linkedin.venice.pushmonitor.WaitAllPushStatusDecider
 
hasEnoughReplicasForOnePartition(int, int) - Method in class com.linkedin.venice.pushmonitor.WaitNMinusOnePushStatusDecider
 
hasError() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
hasErrorInStorageNodeResponse(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
hasErrorInStorageNodeResponse(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
hasFatalDataValidationError() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
hasFatalDataValidationError() - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
hash(byte[]) - Method in class com.linkedin.alpini.base.hash.FnvHashFunction
 
hash(byte[], int) - Method in class com.linkedin.alpini.base.hash.FnvHashFunction
 
hash(byte[], int) - Method in interface com.linkedin.alpini.base.hash.HashFunction
 
hash(byte[], int) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
hash(long, int) - Method in class com.linkedin.alpini.base.hash.FnvHashFunction
 
hash(long, int) - Method in interface com.linkedin.alpini.base.hash.HashFunction
 
hash(long, int) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
hash(ByteBuffer) - Method in class com.linkedin.alpini.base.hash.FnvHashFunction
 
hash(ByteBuffer) - Method in interface com.linkedin.alpini.base.hash.HashFunction
 
hash(ByteBuffer) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
hash(ByteBuffer, int, int) - Method in class com.linkedin.alpini.base.hash.FnvHashFunction
 
hash(ByteBuffer, int, int) - Method in interface com.linkedin.alpini.base.hash.HashFunction
 
hash(ByteBuffer, int, int) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
HASH - com.linkedin.venice.meta.RoutingStrategy
 
hashCode() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
hashCode() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
hashCode() - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
hashCode() - Method in class com.linkedin.alpini.base.misc.Pair
Compute a hash value for the Pair.
hashCode() - Method in class com.linkedin.alpini.base.misc.TimeValue
 
hashCode() - Method in class com.linkedin.alpini.consts.Level
 
hashCode() - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
 
hashCode() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
hashCode() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
hashCode() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
hashCode() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
hashCode() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
hashCode() - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
 
hashCode() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
 
hashCode() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
hashCode() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
hashCode() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
hashCode() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
hashCode() - Method in class com.linkedin.davinci.utils.ByteArrayKey
 
hashCode() - Method in class com.linkedin.venice.authorization.AceEntry
 
hashCode() - Method in class com.linkedin.venice.authorization.AclBinding
 
hashCode() - Method in class com.linkedin.venice.authorization.Principal
 
hashCode() - Method in class com.linkedin.venice.authorization.Resource
 
hashCode() - Method in class com.linkedin.venice.client.store.ClientConfig
 
hashCode() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
 
hashCode() - Method in class com.linkedin.venice.compression.GzipCompressor
 
hashCode() - Method in class com.linkedin.venice.compression.NoopCompressor
 
hashCode() - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
 
hashCode() - Method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
 
hashCode() - Method in class com.linkedin.venice.kafka.validation.Segment
 
hashCode() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
hashCode() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
hashCode() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
hashCode() - Method in class com.linkedin.venice.meta.Instance
 
hashCode() - Method in class com.linkedin.venice.meta.Partition
 
hashCode() - Method in class com.linkedin.venice.meta.PartitionAssignment
 
hashCode() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
hashCode() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
hashCode() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
hashCode() - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
hashCode() - Method in class com.linkedin.venice.meta.SystemStore
 
hashCode() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
hashCode() - Method in class com.linkedin.venice.meta.VersionImpl
 
hashCode() - Method in class com.linkedin.venice.meta.ZKStore
 
hashCode() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
hashCode() - Method in class com.linkedin.venice.persona.Persona
 
hashCode() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
hashCode() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
hashCode() - Method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
hashCode() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeader
 
hashCode() - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
 
hashCode() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
 
hashCode() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
 
hashCode() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
hashCode() - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
 
hashCode() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
hashCode() - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
hashCode() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
hashCode() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
 
hashCode() - Method in class com.linkedin.venice.router.api.RouterKey
 
hashCode() - Method in class com.linkedin.venice.router.api.VeniceFullHttpResponse
 
hashCode() - Method in class com.linkedin.venice.routerapi.ReplicaState
 
hashCode() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
hashCode() - Method in class com.linkedin.venice.schema.GeneratedSchemaEntry
 
hashCode() - Method in class com.linkedin.venice.schema.GeneratedSchemaID
 
hashCode() - Method in class com.linkedin.venice.schema.rmd.RmdSchemaEntry
 
hashCode() - Method in class com.linkedin.venice.schema.rmd.RmdVersionId
 
hashCode() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
hashCode() - Method in class com.linkedin.venice.schema.SchemaEntry
 
hashCode() - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
Deprecated.
 
hashCode() - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
hashCode() - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
hashCode() - Method in class com.linkedin.venice.serializer.SerializerDeserializerFactory.SchemaPairAndClassContainer
 
hashCode() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
hashCode() - Method in class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
 
hashCode() - Method in class com.linkedin.venice.utils.ByteArray
 
hashCode() - Method in class com.linkedin.venice.utils.Pair
Deprecated.
 
hashCode() - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
hashCode() - Method in class com.linkedin.venice.utils.VeniceProperties
 
hashCode(CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Returns the case-insensitive hash code of the specified string.
HashCodeComparator<T> - Class in com.linkedin.venice.utils
 
HashCodeComparator() - Constructor for class com.linkedin.venice.utils.HashCodeComparator
 
HashFunction - Interface in com.linkedin.alpini.base.hash
Forked from com.linkedin.databus.core.util @ r293057
hashlittle(ByteBuffer, int) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
hashlittle2(ByteBuffer, long) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
hashword(IntBuffer, int) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
hashword2(IntBuffer, long) - Method in class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
hasInSyncReplicas() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionInfo
 
hasLagCaughtUp() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
hasLogger(String) - Method in class com.linkedin.alpini.log.FastLogContext
 
hasLogger(String, Class<? extends MessageFactory>) - Method in class com.linkedin.alpini.log.FastLogContext
 
hasLogger(String, MessageFactory) - Method in class com.linkedin.alpini.log.FastLogContext
 
hasMemoryAddress() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
hasMemorySpaceLeft() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
hasMemorySpaceLeft() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
hasMore() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
hasMoreThanOneHttp2Connection() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
hasMultiplePartitionKeys() - Method in interface com.linkedin.alpini.router.api.ResourcePath
 
hasOffsetAdvanced(List<Long>, List<Long>) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
Checks to see if an offset vector has advanced completely beyond some base offset vector or not.
hasPausedPartitionIngestion() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
hasPendingPartitionIngestionAction(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
hasPersona(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
hasReadAccessToTopic(Request) - Method in class com.linkedin.venice.controller.server.AbstractRoute
Check whether the user has "Read" method access to the related version topics.
hasRecords() - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
 
hasReportedFailure - Variable in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
hasReportedFailure(DataWriterTaskTracker, boolean) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
hasReportedFailure(DataWriterTaskTracker, boolean) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
hasRmdSchema(int) - Method in class com.linkedin.venice.schema.SchemaData
 
hasStore(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
hasStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
hasStore(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
hasStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
hasStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
Only return true for the existing zk shared system store.
hasStore(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Whether the store exists or not.
hasStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
hasStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Test if the input store exists in a cluster.
hasStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
hasSubscription(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
hasSubscription(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Checks if the consumer is currently subscribed to the specified PubSub topic-partition.
hasSubscription(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
hasTimeout() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
hasUpdateSchema(int) - Method in class com.linkedin.venice.schema.SchemaData
 
hasValueSchema(String, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
hasValueSchema(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
This function is used to check whether the value schema id is valid in the given store.
hasValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
This function is used to check whether the value schema id is valid in the given store.
hasValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
hasValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
Check whether the given value schema id exists in the given store or not.
hasValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
hasValueSchema(String, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
hasValueSchema(String, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
Check whether the specified schema id is valid or not
hasViewConfigs(Version, Version) - Method in class com.linkedin.venice.ingestion.control.RealTimeTopicSwitcher
 
hasWriteAccessToTopic(Request) - Method in class com.linkedin.venice.controller.server.AbstractRoute
Check whether the user has "Write" method access to the related version topics.
hasWritePermissionToBatchJobHeartbeatStore(X509Certificate, String) - Method in interface com.linkedin.venice.controller.Admin
 
hasWritePermissionToBatchJobHeartbeatStore(X509Certificate, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Test if the given certificate has the write-access permission for the given batch-job heartbeat store.
HdfsAvroUtils - Class in com.linkedin.venice.hadoop.input.recordreader.avro
 
HDFSSchemaSource - Class in com.linkedin.venice.hadoop.schema
HDFSSchemaSource caches the Value schemes and RMD schemas for a given store on the HDFS and serve them during the Mapper stage.
HDFSSchemaSource(String, String) - Constructor for class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
 
HDFSSchemaSource(String, String, String) - Constructor for class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
 
HEAD - com.linkedin.venice.authorization.Method
 
HeaderNames - Enum in com.linkedin.alpini.base.misc
 
HeaderNames.HeaderNamesProvider - Interface in com.linkedin.alpini.base.misc
 
HeaderNames.XClusterName - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XErrorCauseClass - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XErrorCauseMessage - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XErrorClass - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XErrorInResponse - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XErrorMessage - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XMetrics - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XMultipartContentStatus - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XPartition - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XRequestId - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XResponseBoundary - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XReturnMetrics - Annotation Type in com.linkedin.alpini.base.misc
 
HeaderNames.XServedBy - Annotation Type in com.linkedin.alpini.base.misc
 
headers - Variable in class com.linkedin.venice.unit.kafka.InMemoryKafkaMessage
 
headers() - Method in interface com.linkedin.alpini.netty4.misc.MultipartContent
Returns the headers of this message.
Headers - Interface in com.linkedin.alpini.base.misc
 
HeaderStamp - Class in com.linkedin.alpini.netty4.handlers
 
HeaderStamp(String, String) - Constructor for class com.linkedin.alpini.netty4.handlers.HeaderStamp
 
HeaderStringCache - Class in com.linkedin.alpini.base.misc
 
HeaderStringCache.Cache - Class in com.linkedin.alpini.base.misc
 
HeaderUtils - Enum in com.linkedin.alpini.base.misc
 
HeaderUtils.ContentType - Interface in com.linkedin.alpini.base.misc
 
headSet(E) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
HEALTH - com.linkedin.venice.meta.QueryAction
 
healthChecker() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Returns the ChannelHealthChecker that will be used to check if a Channel is healthy.
healthChecker() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Returns the ChannelHealthChecker that will be used to check if a Channel is healthy.
HealthCheckHandler - Class in com.linkedin.venice.router
 
HealthCheckHandler(HealthCheckStats) - Constructor for class com.linkedin.venice.router.HealthCheckHandler
 
HealthCheckRequest - Class in com.linkedin.venice.listener.request
HealthCheckRequest encapsulates information of a health-check request from routers.
HealthCheckRequest() - Constructor for class com.linkedin.venice.listener.request.HealthCheckRequest
 
HealthCheckStats - Class in com.linkedin.venice.router.stats
 
HealthCheckStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.router.stats.HealthCheckStats
 
heapUsage - Variable in class com.linkedin.venice.stats.VeniceJVMStats
The current memory usage of the heap that is used for object allocation.
HEART_BEAT - Static variable in class com.linkedin.venice.message.KafkaKey
 
heartbeat() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
heartbeat() - Method in interface com.linkedin.venice.hadoop.task.TaskTracker
Report task heartbeat if the execution engine requires it
HEARTBEAT - com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
 
HEARTBEAT - com.linkedin.venice.ingestion.protocol.enums.IngestionAction
 
HEARTBEAT - com.linkedin.venice.system.store.MetaStoreDataType
 
HEARTBEAT_CONTROLLER_INITIAL_DELAY_CONFIG - Static variable in class com.linkedin.venice.status.BatchJobHeartbeatConfigs
 
HEARTBEAT_CONTROLLER_TIMEOUT_CONFIG - Static variable in class com.linkedin.venice.status.BatchJobHeartbeatConfigs
 
HEARTBEAT_CYCLE - Static variable in class com.linkedin.venice.ConfigKeys
 
HEARTBEAT_ENABLED_CONFIG - Static variable in class com.linkedin.venice.status.BatchJobHeartbeatConfigs
 
HEARTBEAT_INITIAL_DELAY_CONFIG - Static variable in class com.linkedin.venice.status.BatchJobHeartbeatConfigs
 
HEARTBEAT_INTERVAL_CONFIG - Static variable in class com.linkedin.venice.status.BatchJobHeartbeatConfigs
 
HEARTBEAT_LAST_HEARTBEAT_IS_DELETE_CONFIG - Static variable in class com.linkedin.venice.status.BatchJobHeartbeatConfigs
 
HEARTBEAT_STORE_CLUSTER_CONFIG - Static variable in class com.linkedin.venice.status.BatchJobHeartbeatConfigs
 
HEARTBEAT_TIMEOUT - Static variable in class com.linkedin.venice.ConfigKeys
 
HEARTBEAT_TIMESTAMP - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
HeartbeatBasedCheckerStats - Class in com.linkedin.venice.controller.lingeringjob
 
HeartbeatBasedCheckerStats(MetricsRepository) - Constructor for class com.linkedin.venice.controller.lingeringjob.HeartbeatBasedCheckerStats
 
HeartbeatBasedLingeringStoreVersionChecker - Class in com.linkedin.venice.controller.lingeringjob
 
HeartbeatBasedLingeringStoreVersionChecker(Duration, Duration, DefaultLingeringStoreVersionChecker, HeartbeatBasedCheckerStats) - Constructor for class com.linkedin.venice.controller.lingeringjob.HeartbeatBasedLingeringStoreVersionChecker
 
HeartbeatGuidV3Generator - Class in com.linkedin.venice.guid
A Guid generator which uses the UUID.nameUUIDFromBytes(byte[]).
HeartbeatMonitoringService - Class in com.linkedin.davinci.stats.ingestion.heartbeat
This service monitors heartbeats.
HeartbeatMonitoringService(MetricsRepository, ReadOnlyStoreRepository, Set<String>, String) - Constructor for class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
heartbeatReporterThread - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
HeartbeatStat - Class in com.linkedin.davinci.stats.ingestion.heartbeat
 
HeartbeatStat(MetricConfig, Set<String>) - Constructor for class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
 
HeartbeatStatReporter - Class in com.linkedin.davinci.stats.ingestion.heartbeat
 
HeartbeatStatReporter(MetricsRepository, String, Set<String>) - Constructor for class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStatReporter
 
HeartbeatVersionedStats - Class in com.linkedin.davinci.stats.ingestion.heartbeat
 
HeartbeatVersionedStats(MetricsRepository, ReadOnlyStoreRepository, Supplier<HeartbeatStat>, StatsSupplier<HeartbeatStatReporter>, Map<String, Map<Integer, Map<Integer, Map<String, Long>>>>, Map<String, Map<Integer, Map<Integer, Map<String, Long>>>>) - Constructor for class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatVersionedStats
 
HELIX_ASSIGNMENT_COMPLETED - Static variable in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
HELIX_ASSISTED - com.linkedin.venice.fastclient.meta.ClientRoutingStrategyType
 
HELIX_ASSISTED_ROUTING - com.linkedin.venice.router.api.VeniceMultiKeyRoutingStrategy
 
HELIX_HYBRID_STORE_QUOTA_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
A config that determines whether to use Helix customized view for hybrid store quota
HELIX_MESSAGE_TYPE - Static variable in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
HELIX_REBALANCE_ALG - Static variable in class com.linkedin.venice.ConfigKeys
 
HELIX_RESOURCE_NOT_CREATED - Static variable in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
HELIX_SEND_MESSAGE_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
HelixAdapterSerializer - Class in com.linkedin.venice.helix
Serializer to adapt venice serializer to PathBasedZkSerializer.
HelixAdapterSerializer() - Constructor for class com.linkedin.venice.helix.HelixAdapterSerializer
 
HelixAdminClient - Interface in com.linkedin.venice.controller
Interface and wrapper for Helix related admin operations needed by Venice when running Helix as a service.
HelixBaseRoutingRepository - Class in com.linkedin.venice.helix
Get routing data from Helix and convert it to our Venice partition and replica objects.
HelixBaseRoutingRepository(SafeHelixManager) - Constructor for class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
HelixClusterMaintenanceModeException - Exception in com.linkedin.venice.controller.exception
 
HelixClusterMaintenanceModeException(String) - Constructor for exception com.linkedin.venice.controller.exception.HelixClusterMaintenanceModeException
 
HelixCustomizedViewOfflinePushRepository - Class in com.linkedin.venice.helix
Extend HelixBaseRoutingRepository to leverage customized view data for offline push.
HelixCustomizedViewOfflinePushRepository(SafeHelixManager, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
 
HelixCustomizedViewOfflinePushRepository.StoreChangeListener - Class in com.linkedin.venice.helix
 
HelixCVBasedPushMonitor - Class in com.linkedin.venice.pushmonitor
An implementation of AbstractPushMonitor that listens to Helix Customized View to determine the push status
HelixCVBasedPushMonitor() - Constructor for class com.linkedin.venice.pushmonitor.HelixCVBasedPushMonitor
 
HelixExternalViewRepository - Class in com.linkedin.venice.helix
Extend HelixBaseRoutingRepository to leverage external view data.
HelixExternalViewRepository(SafeHelixManager) - Constructor for class com.linkedin.venice.helix.HelixExternalViewRepository
 
helixGroupInfo - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Helix group information, maps replicas to their respective groups
HelixGroupInfo - Class in com.linkedin.venice.fastclient.meta
 
HelixGroupInfo(Map<String, Integer>) - Constructor for class com.linkedin.venice.fastclient.meta.HelixGroupInfo
 
HelixGroupLeastLoadedStrategy - Class in com.linkedin.venice.router.api.routing.helix
This strategy is tried to distribute more load to Helix Groups with more capacity.
HelixGroupLeastLoadedStrategy(TimeoutProcessor, long) - Constructor for class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
 
HelixGroupRoundRobinStrategy - Class in com.linkedin.venice.router.api.routing.helix
This simple strategy will try to distribute the load evenly to every Helix Group.
HelixGroupRoundRobinStrategy() - Constructor for class com.linkedin.venice.router.api.routing.helix.HelixGroupRoundRobinStrategy
 
HelixGroupSelectionStrategy - Interface in com.linkedin.venice.router.api.routing.helix
 
HelixGroupSelectionStrategyEnum - Enum in com.linkedin.venice.router.api.routing.helix
 
HelixGroupSelector - Class in com.linkedin.venice.router.api.routing.helix
This class is a thin wrapper of HelixInstanceConfigRepository and HelixGroupSelectionStrategy, and it will delegate all the related API calls to the corresponding objects.
HelixGroupSelector(MetricsRepository, HelixInstanceConfigRepository, HelixGroupSelectionStrategyEnum, TimeoutProcessor) - Constructor for class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
HelixGroupStats - Class in com.linkedin.venice.router.stats
 
HelixGroupStats(MetricsRepository, HelixGroupSelectionStrategy) - Constructor for class com.linkedin.venice.router.stats.HelixGroupStats
 
HelixHybridStoreQuotaRepository - Class in com.linkedin.venice.helix
Extend RoutingTableChangeListener to leverage customized view data for hybrid store quota.
HelixHybridStoreQuotaRepository(SafeHelixManager) - Constructor for class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
 
HelixInstanceConfigRepository - Class in com.linkedin.venice.helix
This repository is used to store the instance config per instance.
HelixInstanceConfigRepository(SafeHelixManager, boolean) - Constructor for class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
HelixInstanceConverter - Class in com.linkedin.venice.helix
Convert between ZNRecord in Helix instanceConfig and Venice instance.
HelixInstanceConverter() - Constructor for class com.linkedin.venice.helix.HelixInstanceConverter
 
HelixLiveInstanceMonitor - Class in com.linkedin.venice.helix
This class is used to monitor the current live instances(Helix participators).
HelixLiveInstanceMonitor(ZkClient, String) - Constructor for class com.linkedin.venice.helix.HelixLiveInstanceMonitor
 
HelixMessageChannelStats - Class in com.linkedin.venice.stats
 
HelixMessageChannelStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.HelixMessageChannelStats
 
HelixParticipationService - Class in com.linkedin.davinci.helix
Venice Participation Service wrapping Helix Participant.
HelixParticipationService(StoreIngestionService, StorageService, StorageMetadataService, VeniceConfigLoader, ReadOnlyStoreRepository, ReadOnlySchemaRepository, MetricsRepository, String, String, int, String, CompletableFuture<SafeHelixManager>, HeartbeatMonitoringService) - Constructor for class com.linkedin.davinci.helix.HelixParticipationService
 
HelixPartitionState - Enum in com.linkedin.venice.helix
An Enum enumerating all valid types of HelixPartitionState.
HelixPartitionStateAccessor - Class in com.linkedin.venice.helix
A parent class to access Helix customized partition state, which is different from the states defined in the state model.
HelixPartitionStateAccessor(HelixManager, String) - Constructor for class com.linkedin.venice.helix.HelixPartitionStateAccessor
 
HelixPartitionStatusAccessor - Class in com.linkedin.venice.helix
A class for accessing partition offline push and hybrid quota status in Helix customized state (per Helix instance) on Zookeeper
HelixPartitionStatusAccessor(HelixManager, String, boolean) - Constructor for class com.linkedin.venice.helix.HelixPartitionStatusAccessor
 
HelixReadOnlyLiveClusterConfigRepository - Class in com.linkedin.venice.helix
This class is used to cache live cluster configs.
HelixReadOnlyLiveClusterConfigRepository(ZkClient, HelixAdapterSerializer, String) - Constructor for class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
 
HelixReadOnlySchemaRepository - Class in com.linkedin.venice.helix
This class is used to cache store schema and provide various query operations.
HelixReadOnlySchemaRepository(ReadOnlyStoreRepository, ZkClient, HelixAdapterSerializer, String, int, long) - Constructor for class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
HelixReadOnlySchemaRepositoryAdapter - Class in com.linkedin.venice.helix
This repository provides the read-only access to both system stores and regular stores.
HelixReadOnlySchemaRepositoryAdapter(HelixReadOnlyZKSharedSchemaRepository, ReadOnlySchemaRepository) - Constructor for class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
HelixReadOnlyStoreConfigRepository - Class in com.linkedin.venice.helix
This class is used to fetch all store configs from ZK and cached locally, then provide the way to read those configs.
HelixReadOnlyStoreConfigRepository(ZkClient, HelixAdapterSerializer, int, long) - Constructor for class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
HelixReadOnlyStoreConfigRepository(ZkClient, ZkStoreConfigAccessor, int, long) - Constructor for class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
HelixReadOnlyStoreConfigRepository.StoreConfigAddedOrDeletedChangedListener - Class in com.linkedin.venice.helix
 
HelixReadOnlyStoreConfigRepository.StoreConfigChangedListener - Class in com.linkedin.venice.helix
 
HelixReadOnlyStoreRepository - Class in com.linkedin.venice.helix
 
HelixReadOnlyStoreRepository(ZkClient, HelixAdapterSerializer, String, int, long) - Constructor for class com.linkedin.venice.helix.HelixReadOnlyStoreRepository
 
HelixReadOnlyStoreRepositoryAdapter - Class in com.linkedin.venice.helix
This repository provides an read only interface to access both system store and regular venice store.
HelixReadOnlyStoreRepositoryAdapter(HelixReadOnlyZKSharedSystemStoreRepository, ReadOnlyStoreRepository, String) - Constructor for class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
HelixReadOnlyStoreRepositoryAdapter.VeniceStoreDataChangedListener - Class in com.linkedin.venice.helix
HelixReadOnlyZKSharedSchemaRepository - Class in com.linkedin.venice.helix
This repository is used to retrieve all the zk shared system store schemas from the system store cluster.
HelixReadOnlyZKSharedSchemaRepository(HelixReadOnlyZKSharedSystemStoreRepository, ZkClient, HelixAdapterSerializer, String, int, long) - Constructor for class com.linkedin.venice.helix.HelixReadOnlyZKSharedSchemaRepository
 
HelixReadOnlyZKSharedSystemStoreRepository - Class in com.linkedin.venice.helix
This repository provides an interface to access zk shared system stores only.
HelixReadOnlyZKSharedSystemStoreRepository(ZkClient, HelixAdapterSerializer, String) - Constructor for class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
 
HelixReadWriteLiveClusterConfigRepository - Class in com.linkedin.venice.helix
This class is used to modify live cluster configs.
HelixReadWriteLiveClusterConfigRepository(ZkClient, HelixAdapterSerializer, String) - Constructor for class com.linkedin.venice.helix.HelixReadWriteLiveClusterConfigRepository
 
HelixReadWriteSchemaRepository - Class in com.linkedin.venice.helix
This class is used to add schema entries for stores.
HelixReadWriteSchemaRepository(ReadWriteStoreRepository, Optional<MetaStoreWriter>, HelixSchemaAccessor) - Constructor for class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
HelixReadWriteSchemaRepository(ReadWriteStoreRepository, ZkClient, HelixAdapterSerializer, String, Optional<MetaStoreWriter>) - Constructor for class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
HelixReadWriteSchemaRepositoryAdapter - Class in com.linkedin.venice.helix
This repository supports the following operations: 1.
HelixReadWriteSchemaRepositoryAdapter(HelixReadOnlyZKSharedSchemaRepository, ReadWriteSchemaRepository) - Constructor for class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
HelixReadWriteStoreRepository - Class in com.linkedin.venice.helix
Read write store repository which uses Helix as storage.
HelixReadWriteStoreRepository(ZkClient, HelixAdapterSerializer, String, Optional<MetaStoreWriter>, ClusterLockManager) - Constructor for class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
HelixReadWriteStoreRepositoryAdapter - Class in com.linkedin.venice.helix
This repository provides an read-write interface to access both system store and regular venice store.
HelixReadWriteStoreRepositoryAdapter(HelixReadOnlyZKSharedSystemStoreRepository, ReadWriteStoreRepository, String) - Constructor for class com.linkedin.venice.helix.HelixReadWriteStoreRepositoryAdapter
 
HelixScatterGatherRoutingStrategy - Class in com.linkedin.venice.fastclient.meta
This strategy will assign an ordering of helix groups via round-robin for even distribution.
HelixScatterGatherRoutingStrategy(InstanceHealthMonitor) - Constructor for class com.linkedin.venice.fastclient.meta.HelixScatterGatherRoutingStrategy
 
HelixSchemaAccessor - Class in com.linkedin.venice.helix
 
HelixSchemaAccessor(ZkClient, HelixAdapterSerializer, String) - Constructor for class com.linkedin.venice.helix.HelixSchemaAccessor
 
HelixSchemaAccessor(ZkClient, HelixAdapterSerializer, String, int, long) - Constructor for class com.linkedin.venice.helix.HelixSchemaAccessor
 
HelixState - Enum in com.linkedin.venice.helix
States of Venice node in Helix.
HelixStatusMessageChannel - Class in com.linkedin.venice.helix
The control message changed built on Helix message service.
HelixStatusMessageChannel(SafeHelixManager, HelixMessageChannelStats) - Constructor for class com.linkedin.venice.helix.HelixStatusMessageChannel
 
HelixStatusMessageChannel(SafeHelixManager, HelixMessageChannelStats, int) - Constructor for class com.linkedin.venice.helix.HelixStatusMessageChannel
 
HelixStoreGraveyard - Class in com.linkedin.venice.helix
 
HelixStoreGraveyard(ZkClient, HelixAdapterSerializer, Collection<String>) - Constructor for class com.linkedin.venice.helix.HelixStoreGraveyard
 
HelixStoreGraveyard(ZkClient, HelixAdapterSerializer, Collection<String>, VeniceSerializer<Store>) - Constructor for class com.linkedin.venice.helix.HelixStoreGraveyard
 
HelixUtils - Class in com.linkedin.venice.utils
Helper functions for Helix.
HelixUtils() - Constructor for class com.linkedin.venice.utils.HelixUtils
 
HelixVeniceClusterResources - Class in com.linkedin.venice.controller
Aggregate all essentials resources required by controller to manage a Venice cluster.
HelixVeniceClusterResources(String, ZkClient, HelixAdapterSerializer, SafeHelixManager, VeniceControllerConfig, VeniceHelixAdmin, MetricsRepository, RealTimeTopicSwitcher, Optional<DynamicAccessController>, HelixAdminClient) - Constructor for class com.linkedin.venice.controller.HelixVeniceClusterResources
 
HelixViewPropertyType - Enum in com.linkedin.venice.helix
 
HELP - com.linkedin.venice.Arg
 
HIGH - com.linkedin.alpini.consts.QOS
 
HIGHEST_PRIORITY_W_FAIR_ALLOCATION - com.linkedin.alpini.base.queuing.QOSPolicy
 
HIGHEST_PRIORITY_W_FAIR_ALLOCATION_MULTI_QUEUE - com.linkedin.alpini.base.queuing.QOSPolicy
 
hitCount() - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
hitCount() - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns the approximate number of cache requests which were hits
hitRate() - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
hitRate() - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns the ratio of cache requests which were hits.
hostFinder(HostFinder<HOST, R>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
HostFinder<H,​R> - Interface in com.linkedin.alpini.router.api
Provides methods to locate the storage node or nodes for database partitions.
hostHealthMonitor(HostHealthMonitor<H>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
HostHealthMonitor<H> - Interface in com.linkedin.alpini.router.api
This is an interface for monitoring the healthiness of storage nodes.
HostHealthStats - Class in com.linkedin.venice.router.stats
This class is used to monitor the various reasons for unhealthy hosts.
HostHealthStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.router.stats.HostHealthStats
 
hostLevelIngestionStats - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
HostLevelIngestionStats - Class in com.linkedin.davinci.stats
This class contains stats for stats on the storage node host level.
HostLevelIngestionStats(MetricsRepository, VeniceServerConfig, String, HostLevelIngestionStats, Map<String, StoreIngestionTask>, Time) - Constructor for class com.linkedin.davinci.stats.HostLevelIngestionStats
 
hostName - Variable in class com.linkedin.venice.kafka.protocol.LeaderMetadata
The identifier of the host which sends the message.This helps detect the 'split brain' scenario in leader SN.
HOSTNAME - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
HOURS_PER_DAY - Static variable in interface com.linkedin.venice.utils.Time
 
HTTP - Static variable in class com.linkedin.venice.HttpConstants
 
HTTP_0_9 - Static variable in class com.linkedin.alpini.netty4.handlers.HttpVersionFilter
 
HTTP_1_1_BASED_R2_CLIENT - com.linkedin.venice.fastclient.utils.ClientTestUtils.FastClientHTTPVariant
 
HTTP_2_0 - Static variable in class com.linkedin.alpini.netty4.http2.Http2StreamFrameServerCodec
 
HTTP_2_BASED_HTTPCLIENT5 - com.linkedin.venice.fastclient.utils.ClientTestUtils.FastClientHTTPVariant
 
HTTP_2_BASED_R2_CLIENT - com.linkedin.venice.fastclient.utils.ClientTestUtils.FastClientHTTPVariant
 
HTTP_CLIENT_5_CLIENT - com.linkedin.venice.router.httpclient.StorageNodeClientType
 
HTTP_DATE_FORMAT - Static variable in enum com.linkedin.alpini.base.misc.HeaderUtils
 
HTTP_DATE_GMT_TIMEZONE - Static variable in enum com.linkedin.alpini.base.misc.HeaderUtils
 
HTTP_GET - Static variable in class com.linkedin.venice.HttpConstants
 
HTTP_METHOD_GET_LOWER_CASE - Static variable in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
 
HTTP_METHOD_POST_LOWER_CASE - Static variable in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
 
HTTP_PREFIX - Static variable in class com.linkedin.venice.HttpConstants
 
HTTP_TO_HTTP2_HEADER_DENY_LIST - Static variable in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
The set of headers that should not be directly copied when converting headers from HTTP to HTTP/2.
HTTP_TOO_MANY_REQUESTS - Static variable in exception com.linkedin.venice.client.exceptions.VeniceClientRateExceededException
 
Http1FullRequest - Class in com.linkedin.alpini.netty4.http2
An implementation of BasicFullHttpRequest which always uses a Http1Headers for holding the headers.
Http1FullRequest(FullHttpRequest) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullRequest(HttpRequest, Http1Headers, Http1Headers, ByteBuf) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullRequest(HttpVersion, ByteBuf, Http1Headers, UUID, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullRequest(HttpVersion, HttpMethod, String, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullRequest(HttpVersion, HttpMethod, String, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullRequest(HttpVersion, HttpMethod, String, ByteBuf, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullRequest(HttpVersion, HttpMethod, String, ByteBuf, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullRequest(HttpVersion, HttpMethod, String, ByteBuf, HttpHeaders, HttpHeaders, UUID, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullRequest
 
Http1FullResponse - Class in com.linkedin.alpini.netty4.http2
An implementation of BasicFullHttpResponse which always uses a Http1Headers for holding the headers.
Http1FullResponse(FullHttpResponse) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullResponse
 
Http1FullResponse(HttpRequest, ByteBuf, Http1Headers, Http1Headers) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullResponse
 
Http1FullResponse(HttpRequest, HttpResponseStatus) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullResponse
 
Http1FullResponse(HttpRequest, HttpResponseStatus, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullResponse
 
Http1FullResponse(HttpRequest, HttpResponseStatus, ByteBuf) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullResponse
 
Http1FullResponse(HttpRequest, HttpResponseStatus, ByteBuf, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullResponse
 
Http1FullResponse(HttpResponse, Http1Headers, Http1Headers, ByteBuf) - Constructor for class com.linkedin.alpini.netty4.http2.Http1FullResponse
 
Http1Headers - Class in com.linkedin.alpini.netty4.http2
 
Http1Headers(boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Headers
 
Http1Headers(Http2Headers, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Headers
 
Http1Request - Class in com.linkedin.alpini.netty4.http2
An implementation of BasicHttpRequest which always uses a Http1Headers for holding the headers.
Http1Request(HttpRequest) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Request
 
Http1Request(HttpRequest, Http1Headers) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Request
 
Http1Request(HttpVersion, Http1Headers, UUID, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Request
 
Http1Request(HttpVersion, HttpMethod, String) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Request
 
Http1Request(HttpVersion, HttpMethod, String, boolean, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Request
 
Http1Request(HttpVersion, HttpMethod, String, long, long) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Request
 
Http1Response - Class in com.linkedin.alpini.netty4.http2
An implementation of BasicHttpResponse which always uses a Http1Headers for holding the headers.
Http1Response(HttpRequest, Http1Headers) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Response
 
Http1Response(HttpRequest, HttpResponseStatus) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Response
 
Http1Response(HttpRequest, HttpResponseStatus, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Response
 
Http1Response(HttpResponse) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Response
 
Http1Response(HttpResponse, Http1Headers) - Constructor for class com.linkedin.alpini.netty4.http2.Http1Response
 
HTTP2_CONNECTION - Static variable in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
HTTP2_REUSED_STREAM_CHANNEL - Static variable in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
HTTP2_STREAM_CHANNEL_AVAILABLE_FOR_REUSE - Static variable in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
Http2AwareChannelPool - Class in com.linkedin.alpini.netty4.pool
A ChannelPool Wrapper that would return either a ChannelPool if the request is an HTTP 1.1 request or A Stream if HTTP2
Http2AwareChannelPool(ManagedChannelPool, Consumer<Channel>, Consumer<Channel>) - Constructor for class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
Http2AwareChannelPool(ManagedChannelPool, Consumer<Channel>, Consumer<Channel>, boolean) - Constructor for class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
Http2AwareChannelPool(ManagedChannelPool, Consumer<Channel>, Consumer<Channel>, boolean, ChannelGroup) - Constructor for class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
http2Connection(Channel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
Http2ExceptionHandler - Class in com.linkedin.alpini.netty4.handlers
This class is ExceptionHandler for all HTTP/2.
Http2ExceptionHandler() - Constructor for class com.linkedin.alpini.netty4.handlers.Http2ExceptionHandler
 
http2HeaderTableSize(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
http2HeaderTableSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
http2HeaderTableSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
http2InitialWindowSize(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
http2InitialWindowSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
http2InitialWindowSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
http2MaxConcurrentStreams(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
http2MaxConcurrentStreams(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
http2MaxConcurrentStreams(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
http2MaxFrameSize(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
http2MaxFrameSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
http2MaxFrameSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
http2MaxHeaderListSize(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
http2MaxHeaderListSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
http2MaxHeaderListSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
http2MultiplexHandler(boolean, ChannelPipeline) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
Http2PingCallListener - Interface in com.linkedin.alpini.netty4.pool
 
Http2PingHelper - Class in com.linkedin.alpini.netty4.pool
 
Http2PingHelper() - Constructor for class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
Http2PingResponseHandler - Class in com.linkedin.alpini.netty4.handlers
 
Http2PingResponseHandler() - Constructor for class com.linkedin.alpini.netty4.handlers.Http2PingResponseHandler
 
Http2PingSendHandler - Class in com.linkedin.alpini.netty4.handlers
 
Http2PingSendHandler(Http2PingCallListener) - Constructor for class com.linkedin.alpini.netty4.handlers.Http2PingSendHandler
 
Http2PipelineInitializer - Class in com.linkedin.alpini.netty4.http2
Initializes HTTP/2 Pipeline.
Http2PipelineInitializer(Http2Settings, ActiveStreamsCountHandler, Http2SettingsFrameLogger, Consumer<ChannelPipeline>, int, int, int, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
Http2PipelineInitializer(Http2Settings, ActiveStreamsCountHandler, Http2SettingsFrameLogger, Consumer<ChannelPipeline>, int, int, int, boolean, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
Deprecated.
Http2PipelineInitializer.Builder<T extends Http2PipelineInitializer.Builder<T>> - Class in com.linkedin.alpini.netty4.http2
 
Http2PipelineInitializer.BuilderSupplier - Interface in com.linkedin.alpini.netty4.http2
 
http2Settings(Http2Settings) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
http2SettingsFrameLogger(Http2SettingsFrameLogger) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
Http2SettingsFrameLogger - Class in com.linkedin.alpini.netty4.handlers
Logs the HTTP/2 Settings Frames.
Http2SettingsFrameLogger(LogLevel) - Constructor for class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
Http2SettingsFrameLogger(LogLevel, Class<?>) - Constructor for class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
Http2SettingsFrameLogger(LogLevel, String) - Constructor for class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
Http2StreamFrameClientCodec - Class in com.linkedin.alpini.netty4.http2
 
Http2StreamFrameClientCodec() - Constructor for class com.linkedin.alpini.netty4.http2.Http2StreamFrameClientCodec
 
Http2StreamFrameClientCodec(boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http2StreamFrameClientCodec
 
Http2StreamFrameServerCodec - Class in com.linkedin.alpini.netty4.http2
 
Http2StreamFrameServerCodec() - Constructor for class com.linkedin.alpini.netty4.http2.Http2StreamFrameServerCodec
 
Http2StreamFrameServerCodec(HttpVersion, boolean) - Constructor for class com.linkedin.alpini.netty4.http2.Http2StreamFrameServerCodec
 
Http2TooManyStreamsException - Exception in com.linkedin.alpini.base.misc
Client-facing exception for HTTP/2 too many active streams exception with a clearer message for the clients.
Http2Utils - Class in com.linkedin.alpini.netty4.misc
HTTP/2 utility methods.
HttpByteBufContentChunker - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 3/23/17.
HttpByteBufContentChunker(int, int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpByteBufContentChunker
 
HttpChannelInitializer - Class in com.linkedin.venice.listener
 
HttpChannelInitializer(ReadOnlyStoreRepository, CompletableFuture<HelixCustomizedViewOfflinePushRepository>, MetricsRepository, Optional<SSLFactory>, Executor, VeniceServerConfig, Optional<StaticAccessController>, Optional<DynamicAccessController>, StorageReadRequestHandler) - Constructor for class com.linkedin.venice.listener.HttpChannelInitializer
 
HttpClient5BasedR2Client - Class in com.linkedin.venice.fastclient.transport
This utility class could construct a HttpClient5 based R2 Client.
HttpClient5BasedR2Client() - Constructor for class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
 
HttpClient5Builder() - Constructor for class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
HttpClient5StorageNodeClient - Class in com.linkedin.venice.router.httpclient
 
HttpClient5StorageNodeClient(Optional<SSLFactory>, VeniceRouterConfig) - Constructor for class com.linkedin.venice.router.httpclient.HttpClient5StorageNodeClient
 
HttpClient5Utils - Class in com.linkedin.venice.httpclient5
This class is used to provide a facility to initialize httpclient5 lib based Http/2 Client.
HttpClient5Utils() - Constructor for class com.linkedin.venice.httpclient5.HttpClient5Utils
 
HttpClient5Utils.HttpClient5Builder - Class in com.linkedin.venice.httpclient5
 
HttpClientTransport - Class in com.linkedin.davinci.ingestion
 
HttpClientTransport(Optional<SSLFactory>, int, int) - Constructor for class com.linkedin.davinci.ingestion.HttpClientTransport
 
HttpClientUtils - Class in com.linkedin.venice.httpclient
 
HttpClientUtils() - Constructor for class com.linkedin.venice.httpclient.HttpClientUtils
 
HttpClientUtils.ClosableHttpAsyncClientWithConnManager - Class in com.linkedin.venice.httpclient
 
HttpConnectionPoolStats - Class in com.linkedin.venice.stats
 
HttpConnectionPoolStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.HttpConnectionPoolStats
 
HttpConstants - Class in com.linkedin.venice
 
HttpContentMultiPartAggregator - Class in com.linkedin.alpini.netty4.handlers
Aggregates the result of HttpContentMultiPartDecode into FullHttpMultiPart This uses HttpMultiPartContentAggregator to aggregate the FullHttpMultiPart messages and bypasses the aggregator when not aggregating multipart messages.
HttpContentMultiPartAggregator(int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartAggregator
 
HttpContentMultiPartDecode - Class in com.linkedin.alpini.netty4.handlers
Decodes ByteBuf objects as HttpMultiPart headers and content.
HttpContentMultiPartDecode(HttpContentUnwrap, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartDecode
 
HttpContentUnwrap - Class in com.linkedin.alpini.netty4.handlers
Unwraps the content of messages which have multipart bodies as bare ByteBuf messages which can then be further processed by HttpContentMultiPartDecode.
HttpContentUnwrap() - Constructor for class com.linkedin.alpini.netty4.handlers.HttpContentUnwrap
 
HttpMethod - Enum in com.linkedin.venice
 
HttpMultiPart - Interface in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/22/17.
HttpMultiPartContentAggregator - Class in com.linkedin.alpini.netty4.handlers
This _only_ knows how to aggregate HttpMultiPart messages and "bad things"(tm) will occur when it encounters other types of messages.
HttpMultiPartContentAggregator(int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
HttpMultiPartContentCodec - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 3/22/17.
HttpMultiPartContentCodec(int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentCodec
 
HttpMultiPartContentCodec(IntSupplier, IntSupplier, IntSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentCodec
 
HttpMultiPartContentDecoder - Class in com.linkedin.alpini.netty4.handlers
Decodes MIME multipart encoded content bodies by separating them into separate HttpMessage objects.
HttpMultiPartContentDecoder(int, int, int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentDecoder
 
HttpMultiPartContentDecoder(IntSupplier, IntSupplier, IntSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentDecoder
 
HttpMultiPartContentDecoder(IntSupplier, IntSupplier, IntSupplier, boolean, int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentDecoder
 
HttpMultiPartContentEncoder - Class in com.linkedin.alpini.netty4.handlers
Encodes a stream of HttpMultiPart objects into a MIME encoded document.
HttpMultiPartContentEncoder() - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentEncoder
 
HttpMultiPartContentEncoder(int, int) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentEncoder
 
HttpObjectToBasicHttpObjectAdapter - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 4/26/18.
HttpObjectToBasicHttpObjectAdapter() - Constructor for class com.linkedin.alpini.netty4.handlers.HttpObjectToBasicHttpObjectAdapter
 
HTTPS - Static variable in class com.linkedin.venice.client.store.transport.TransportClient
 
HTTPS - Static variable in class com.linkedin.venice.HttpConstants
 
HTTPS_POST - Static variable in class com.linkedin.venice.HttpConstants
 
HTTPS_PREFIX - Static variable in class com.linkedin.venice.HttpConstants
 
HttpServerConcurrencyObserver - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 12/6/17.
HttpServerConcurrencyObserver(CallTracker) - Constructor for class com.linkedin.alpini.netty4.handlers.HttpServerConcurrencyObserver
 
HttpServerStatisticsHandler - Class in com.linkedin.alpini.netty4.handlers
An abstract handler which may be used to examine latencies in the Netty4 HTTP request processing.
HttpServerStatisticsHandler() - Constructor for class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler
 
HttpServerStatisticsHandler.Stats - Class in com.linkedin.alpini.netty4.handlers
 
HttpShortcutResponse - Class in com.linkedin.venice.listener.response
Created by mwise on 3/11/16.
HttpShortcutResponse(String, HttpResponseStatus) - Constructor for class com.linkedin.venice.listener.response.HttpShortcutResponse
 
HttpsTransportClient - Class in com.linkedin.venice.client.store.transport
 
HttpsTransportClient(String, int, int, boolean, SSLFactory) - Constructor for class com.linkedin.venice.client.store.transport.HttpsTransportClient
 
HttpsTransportClient(String, CloseableHttpAsyncClient) - Constructor for class com.linkedin.venice.client.store.transport.HttpsTransportClient
 
HttpToStringUtils - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/23/17.
HttpTransportClient - Class in com.linkedin.venice.client.store.transport
CloseableHttpAsyncClient based TransportClient implementation.
HttpTransportClient(String, int, int) - Constructor for class com.linkedin.venice.client.store.transport.HttpTransportClient
 
HttpTransportClient(String, CloseableHttpAsyncClient) - Constructor for class com.linkedin.venice.client.store.transport.HttpTransportClient
 
HttpUtils - Enum in com.linkedin.alpini.netty4.misc
This will be used to stash reoccurring common bits of code.
HttpVersionFilter - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 9/28/17.
HttpVersionFilter() - Constructor for class com.linkedin.alpini.netty4.handlers.HttpVersionFilter
 
hybrid - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether the store is hybrid.
hybrid - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
HYBRID_BUFFER_REPLAY_POLICY - com.linkedin.venice.Arg
 
HYBRID_DATA_REPLICATION_POLICY - com.linkedin.venice.Arg
 
HYBRID_FOLLOWER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
HYBRID_LEADER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
HYBRID_OFFSET_LAG - com.linkedin.venice.Arg
 
HYBRID_ONLY - com.linkedin.venice.meta.VeniceUserStoreType
The data in hybrid stores will be populated by offline pushes/Samza reprocessing as well as Samza real-time updates.
HYBRID_OR_INCREMENTAL - com.linkedin.venice.meta.VeniceUserStoreType
These stores are either hybrid or incremental push enabled.
HYBRID_QUOTA_ENFORCEMENT_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
HYBRID_REWIND_SECONDS - com.linkedin.venice.Arg
 
HYBRID_STORE - com.linkedin.venice.pushmonitor.PushMonitorType
 
HYBRID_STORE_DISK_QUOTA_ENABLED - com.linkedin.venice.Arg
 
HYBRID_STORE_DISK_QUOTA_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
HYBRID_STORE_OVERHEAD_BYPASS - com.linkedin.venice.Arg
 
HYBRID_STORE_OVERHEAD_BYPASS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
HYBRID_STORE_QUOTA - com.linkedin.venice.helix.HelixPartitionState
 
HYBRID_TIME_LAG - com.linkedin.venice.Arg
 
hybridConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Properties related to Hybrid Store behavior.
hybridConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Properties related to Hybrid Store behavior.
HybridQuotaMonitorTask(TransportClient, String, String, RouterBasedHybridStoreQuotaMonitor, RouterBasedHybridStoreQuotaMonitor.TransportClientReinitProvider) - Constructor for class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor.HybridQuotaMonitorTask
 
hybridStoreConfig - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
hybridStoreConfig - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
hybridStoreConfig - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
hybridStoreConfig - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
HybridStoreConfig - Class in com.linkedin.venice.meta.systemstore.schemas
 
HybridStoreConfig - Interface in com.linkedin.venice.meta
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
HybridStoreConfig() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
Default constructor.
HybridStoreConfig(Long, Long, Long) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
All-args constructor.
HybridStoreConfigImpl - Class in com.linkedin.venice.meta
A container of Hybrid Store related configurations.
HybridStoreConfigImpl(long, long, long, DataReplicationPolicy, BufferReplayPolicy) - Constructor for class com.linkedin.venice.meta.HybridStoreConfigImpl
 
HybridStoreConfigRecord - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
HybridStoreConfigRecord() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Default constructor.
HybridStoreConfigRecord(Long, Long, Long, Integer, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
All-args constructor.
HybridStoreConfigSerializerMixin(long, long) - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer.HybridStoreConfigSerializerMixin
 
hybridStoreDiskQuotaEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether or not to enable disk storage quota for a hybrid store
hybridStoreDiskQuotaEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
hybridStoreDiskQuotaEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not storage disk quota is enabled for a hybrid store.
hybridStoreOverheadBypass - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
HybridStoreQuotaStatus - Enum in com.linkedin.venice.pushmonitor
 
HybridStoreQuotaStatusResponse - Class in com.linkedin.venice.routerapi
Hybrid store quota status response for a resource; this is a response that will be returned by Router.
HybridStoreQuotaStatusResponse() - Constructor for class com.linkedin.venice.routerapi.HybridStoreQuotaStatusResponse
 

I

icProvider - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
ICProvider - Interface in com.linkedin.venice.service
An interface for implementation of IC( invocation-context) provider class for calls between various deployable services.
id - Variable in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
IDENTITY_PARSER_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
A config to specify the class to use to parse identities at runtime
IdentityParser - Interface in com.linkedin.venice.authorization
An interface that provides a method to parse identity information from a certificate.
IdentityRecordDeserializer - Class in com.linkedin.venice.serialization
This class is used as an identity function to return the same bytes that were passed in the input to the output.
IdentityVeniceRecordReader - Class in com.linkedin.venice.hadoop.input.recordreader.avro
A record reader that returns the input key and value as is.
IDLE_TIME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
idleConnectionTimeoutMillis(long) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
idleCounter - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
idleTimeout(long, TimeUnit) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
idleTimeout(long, TimeUnit) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
ifPresent(Consumer<? super C>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
ifPresent(Consumer<? super T>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
 
ifPresent(Consumer<? super T>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
ignite(String, int, SslStores, int, int, int) - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
IGNORE_VERSION - Static variable in interface com.linkedin.venice.meta.Store
 
ignoreContentAfterContinueResponse(Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
ignoreContentAfterContinueResponse(Object) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Determine if all objects for the current request/response should be ignored or not.
ignoreContentAfterContinueResponse(Object) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
IGNORED_COMPRESSION_DICT - Static variable in class com.linkedin.davinci.listener.response.AdminResponse
 
IGNORED_CURRENT_VERSION - Static variable in class com.linkedin.venice.controller.kafka.consumer.AdminConsumptionTask
 
IGNORED_TOPIC_NAME - Static variable in class com.linkedin.venice.serialization.KeyWithChunkingSuffixSerializer
 
ILLEGAL_AVRO_CHARACTER - Static variable in class com.linkedin.venice.compute.ComputeUtils
 
ILLEGAL_AVRO_CHARACTER_REPLACEMENT - Static variable in class com.linkedin.venice.compute.ComputeUtils
 
ImmutableChangeCapturePubSubMessage<K,​V> - Class in com.linkedin.davinci.consumer
 
ImmutableChangeCapturePubSubMessage(K, V, PubSubTopicPartition, long, long, int, boolean) - Constructor for class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
ImmutableMapEntry<K,​V> - Class in com.linkedin.alpini.base.misc
A Pair which may be used as a Map.Entry.
ImmutableMapEntry(K, V) - Constructor for class com.linkedin.alpini.base.misc.ImmutableMapEntry
 
ImmutablePubSubMessage<K,​V> - Class in com.linkedin.venice.pubsub
 
ImmutablePubSubMessage(K, V, PubSubTopicPartition, long, long, int) - Constructor for class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
ImmutablePubSubMessage(K, V, PubSubTopicPartition, long, long, int, PubSubMessageHeaders) - Constructor for class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
ImproperlyStartedSegmentException - Exception in com.linkedin.venice.exceptions.validation
This exception is thrown when we detect a new producer which did not start with a ControlMessageType.START_OF_SEGMENT.
ImproperlyStartedSegmentException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.ImproperlyStartedSegmentException
 
ImproperlyStartedSegmentException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.validation.ImproperlyStartedSegmentException
 
IN_MEMORY - com.linkedin.venice.meta.PersistenceType
Volatile storage engine based on a simple Java ConcurrentHashMap.
IN_PROGRESS - com.linkedin.venice.kafka.validation.SegmentStatus
IN_TRANSITION_FROM_STANDBY_TO_LEADER - com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
This partition is in the transition process from follower to leader, but it hasn't finished doing all the status check yet; so it's still running as a follower, but it will switch to the leader role at anytime.
INACTIVE_STORE_INGESTION_TASK - com.linkedin.venice.stats.StatsErrorCode
Inactive StoreIngestionTask instances should not be asked for metrics in the first place, but in case they are, there is a check that will prevent them from being interrogated.
INANIMATE - com.linkedin.venice.controllerapi.NodeReplicasReadinessState
Node is not live.
InboundContentDebugHandler - Class in com.linkedin.alpini.netty4.handlers
In order to dump the HTTP headers when there is a decode failure, surround the HTTP decode handler with these handles...example:
InboundContentDebugHandler(int) - Constructor for class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler
 
InboundContentDebugHandler(IntSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler
 
InboundContentDebugHandler.HttpDecodeResult - Class in com.linkedin.alpini.netty4.handlers
 
INCLUDE_SYSTEM_STORES - com.linkedin.venice.Arg
 
INCLUDE_SYSTEM_STORES - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
IncomingDataAfterSegmentEndedException - Exception in com.linkedin.venice.exceptions.validation
This exception is thrown when the server reads data from same segment after the segment is ended.
IncomingDataAfterSegmentEndedException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.IncomingDataAfterSegmentEndedException
 
IncomingDataAfterSegmentEndedException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.validation.IncomingDataAfterSegmentEndedException
 
INCOMPATIBLE - com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaCompatibilityType
 
INCORRECT_CONTROLLER - com.linkedin.venice.exceptions.ErrorType
 
INCORRECT_CONTROLLER - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
incrCollectedNumberOfSamples() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
 
incrDuplicateKeyWithDistinctValue(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrDuplicateKeyWithIdenticalValue(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
increaseCount(boolean) - Method in class com.linkedin.alpini.base.misc.CounterQueue
Non-thread safe method but it would only be called by a single thread.
increment(boolean) - Method in class com.linkedin.alpini.base.misc.RetryCounter
 
incrementAcquiredChannelCount() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
INCREMENTAL - com.linkedin.venice.meta.Version.PushType
 
INCREMENTAL_PUSH - com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
 
INCREMENTAL_PUSH - com.linkedin.venice.meta.VeniceUserStoreType
The data in these stores are from full pushes and incremental pushes.
INCREMENTAL_PUSH - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
INCREMENTAL_PUSH_ENABLED - com.linkedin.venice.Arg
 
INCREMENTAL_PUSH_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
INCREMENTAL_PUSH_VERSION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
IncrementalPush - Class in com.linkedin.venice.kafka.protocol.state
 
IncrementalPush() - Constructor for class com.linkedin.venice.kafka.protocol.state.IncrementalPush
Default constructor.
IncrementalPush(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.kafka.protocol.state.IncrementalPush
All-args constructor.
incrementalPushEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
a flag to see if the store supports incremental push or not
incrementalPushEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
incrementalPushEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Flag to see if the store supports incremental push or not
incrementalPushEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Flag to see if the store supports incremental push or not
incrementalPushInfo - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
metadata of ongoing incremental push in the partition
incrementalPushPolicy - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Incremental Push Policy to reconcile with real time pushes.
incrementalPushPolicy - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Incremental Push Policy to reconcile with real time pushes, and default is 'PUSH_TO_VERSION_TOPIC'
incrementalPushPolicy - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Incremental Push Policy to reconcile with real time pushes., and default is 'PUSH_TO_VERSION_TOPIC'
incrementalPushPolicyToApply - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
This field will determine what incremental push policy will be applied to the selected stores.
incrementalPushPolicyToFilter - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
If this batch update command is trying to configure existing incremental push store type, their incremental push policy should also match this filter before the batch update command applies any change to them.
incrementalPushVersion - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
IncrementalPushVersionsResponse - Class in com.linkedin.venice.controllerapi
 
IncrementalPushVersionsResponse() - Constructor for class com.linkedin.venice.controllerapi.IncrementalPushVersionsResponse
 
incrementAndGetExecutionId(String) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
incrementAndGetExecutionId(String) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
Read the current value from ZK and try to increment the value by 1 and write it back to ZK.
incrementAndGetExecutionId(String) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
Using AtomicLong here only as a workaround to get next execution id from HelixUtils.compareAndUpdate(ZkBaseDataAccessor, String, int, DataUpdater)
incrementAttempt() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
incrementClientConnectionCount() - Method in class com.linkedin.venice.stats.ServerConnectionStats
 
incrementCosineSimilarityCount(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
incrementCountOperatorCount(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
incrementDotProductCount(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
incrementFanoutRequestsSent(int) - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementHadamardProductCount(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
incrementMultiChunkLargeValueCount() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
incrementMultiChunkLargeValueCount() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
This function needs to be synchronized because during batch gets, there could be several threads incrementing this all at once.
incrementOffset(Map<PubSubTopicPartition, Long>, PubSubTopicPartition, long) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.AbstractPollStrategy
 
incrementProcessedRecordSizeSinceLastSync(int) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
incrementRequestPartCount() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
incrementRouterConnectionCount() - Method in class com.linkedin.venice.stats.ServerConnectionStats
 
incrementThreadBlockedOnOfflineToDroppedTransitionCount() - Method in class com.linkedin.davinci.stats.ParticipantStateTransitionStats
 
incrementTotalRequestsReceived() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriedKeys(int) - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetries() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetries(ScatterGatherStats.Delta, HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
incrementTotalRetriesDiscarded(long) - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriesError() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriesError(ScatterGatherStats.Delta, HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
incrementTotalRetriesOn429() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriesOn503() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriesOn503Error() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriesOn503Winner() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriesWinner() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
 
incrementTotalRetriesWinner(ScatterGatherStats.Delta, HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
incrementVersionIdempotent(String, String, String, int, int) - Method in interface com.linkedin.venice.controller.Admin
The implementation of this method must take no action and return the same Version object if the same parameters are provided on a subsequent invocation.
incrementVersionIdempotent(String, String, String, int, int, Version.PushType, boolean, boolean, String, Optional<String>, Optional<X509Certificate>, long, Optional<String>, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
incrementVersionIdempotent(String, String, String, int, int, Version.PushType, boolean, boolean, String, Optional<String>, Optional<X509Certificate>, long, Optional<String>, boolean, String) - Method in interface com.linkedin.venice.controller.Admin
 
incrementVersionIdempotent(String, String, String, int, int, Version.PushType, boolean, boolean, String, Optional<String>, Optional<X509Certificate>, long, Optional<String>, boolean, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Note: this currently use the pushID to guarantee idempotence, unexpected behavior may result if multiple batch jobs push to the same store at the same time.
incrementVersionIdempotent(String, String, String, int, int, Version.PushType, boolean, boolean, String, Optional<String>, Optional<X509Certificate>, long, Optional<String>, boolean, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
incrEmptyRecordCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperErrorDataModifiedDuringPushJobCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperInvalidInputFileCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperInvalidInputIdxCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperNumRecordsSuccessfullyProcessedCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperSchemaInconsistencyFailureCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperSprayAllPartitionsTriggeredCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperZstdDictTrainFailureCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperZstdDictTrainSkippedCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrMapperZstdDictTrainSuccessCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrOutputRecordCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrRecordTooLargeFailureCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrReducerClosedCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrRepushTtlFilterCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrTotalGzipCompressedValueSize(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrTotalKeySize(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrTotalPutOrDeleteRecordCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrTotalUncompressedValueSize(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrTotalValueSize(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrTotalZstdCompressedValueSize(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
incrWriteAclAuthorizationFailureCount(Reporter, long) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
INDEX_NOT_FOUND - Static variable in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
IndexedHashMap<K,​V> - Class in com.linkedin.davinci.utils
This is a fork of the standard HashMap which implements IndexedMap.
IndexedHashMap() - Constructor for class com.linkedin.davinci.utils.IndexedHashMap
Constructs an empty IndexedHashMap with the default initial capacity (16) and the default load factor (0.75).
IndexedHashMap(int) - Constructor for class com.linkedin.davinci.utils.IndexedHashMap
Constructs an empty IndexedHashMap with the specified initial capacity and the default load factor (0.75).
IndexedHashMap(int, float) - Constructor for class com.linkedin.davinci.utils.IndexedHashMap
Constructs an empty IndexedHashMap with the specified initial capacity and load factor.
IndexedHashMap(int, float, List<Map.Entry<K, V>>) - Constructor for class com.linkedin.davinci.utils.IndexedHashMap
Constructs an empty IndexedHashMap using the provided list implementation.
IndexedHashMap(Map<? extends K, ? extends V>) - Constructor for class com.linkedin.davinci.utils.IndexedHashMap
Constructs a new IndexedHashMap with the same mappings as the specified Map.
IndexedHashMap(Map<? extends K, ? extends V>, List<Map.Entry<K, V>>) - Constructor for class com.linkedin.davinci.utils.IndexedHashMap
Constructs a new IndexedHashMap with the same mappings as the specified Map.
IndexedMap<K,​V> - Interface in com.linkedin.davinci.utils
The IndexedMap interface implements Map and several functions for dealing with its content via the index corresponding to their insertion order.
IndexedMap<K,​V> - Interface in com.linkedin.venice.utils
The IndexedMap interface implements Map and several functions for dealing with its content via the index corresponding to their insertion order.
indexOf(char, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Searches in this string for the index of the specified char ch.
indexOf(E, int) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
indexOf(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Searches in this string for the first index of the specified string.
indexOf(CharSequence, char, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Finds the first index in the CharSequence that matches the specified character.
indexOf(CharSequence, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Searches in this string for the index of the specified string.
indexOf(K) - Method in class com.linkedin.davinci.utils.IndexedHashMap
Constant-time, as Map.get(Object)
indexOf(K) - Method in interface com.linkedin.davinci.utils.IndexedMap
 
indexOf(K) - Method in interface com.linkedin.venice.utils.IndexedMap
 
indexOfIgnoreCase(CharSequence, CharSequence, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Case in-sensitive find of the first index within a CharSequence from the specified position.
indexOfIgnoreCaseAscii(CharSequence, CharSequence, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Case in-sensitive find of the first index within a CharSequence from the specified position.
INDUSTRY - com.linkedin.venice.utils.TestWriteUtils.TestTargetedField
 
inferSchema(CaseInsensitiveStringMap) - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsSource
 
INFLIGHT - com.linkedin.alpini.base.concurrency.AsyncFuture.Status
 
info(CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
info(CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Message) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
info(MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
info(Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
INFO - Static variable in class com.linkedin.alpini.consts.Level
The INFO level designates informational messages that highlight the progress of the application at coarse-grained level.
INFO_INT - Static variable in class com.linkedin.alpini.consts.Level
 
INGESTION_ISOLATION_CONFIG_PREFIX - Static variable in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
INGESTION_MEMORY_LIMIT - Static variable in class com.linkedin.venice.ConfigKeys
 
INGESTION_MEMORY_LIMIT_STORE_LIST - Static variable in class com.linkedin.venice.ConfigKeys
Only applies the memory limiter to the stores listed in this config.
INGESTION_METRICS_REPORT - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode metrics collected from ingestion task, that are reported backed from child process to Storage Node / Da Vinci backend.
INGESTION_MLOCK_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether the ingestion is using mlock or not.
INGESTION_STORAGE_METADATA - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode storage metadata updates that are reported backed from Storage Node / Da Vinci backend to child process.
INGESTION_TASK_COMMAND - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode various kinds of ingestion task commands, which are used to control ingestion task in child process.
INGESTION_TASK_ERROR_GAUGE - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
INGESTION_TASK_PUSH_TIMEOUT_GAUGE - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
INGESTION_TASK_REPORT - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode status of ingestion task, that are reported backed from child process to Storage Node / Da Vinci backend.
INGESTION_USE_DA_VINCI_CLIENT - Static variable in class com.linkedin.venice.ConfigKeys
A boolean config to specify if we are using Da Vinci client for ingestion.
IngestionAction - Enum in com.linkedin.venice.ingestion.protocol.enums
 
IngestionBackendBase - Interface in com.linkedin.davinci.ingestion
 
IngestionCommandType - Enum in com.linkedin.venice.ingestion.protocol.enums
IngestionCommandType is an Enum class for specifying different commands for ingestion isolation.
IngestionComponentType - Enum in com.linkedin.venice.ingestion.protocol.enums
IngestionComponentType is an Enum class for specifying different components for graceful shutdown in forked ingestion process.
IngestionMetadataRetriever - Interface in com.linkedin.davinci.storage
 
IngestionMetadataUpdateType - Enum in com.linkedin.venice.meta
 
IngestionMetricsReport - Class in com.linkedin.venice.ingestion.protocol
 
IngestionMetricsReport() - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
Default constructor.
IngestionMetricsReport(Map<CharSequence, Double>) - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
All-args constructor.
IngestionMode - Enum in com.linkedin.venice.meta
IngestionMode is an Enum class that contains all modes for ingestion.
IngestionReportType - Enum in com.linkedin.venice.ingestion.protocol.enums
IngestionReportType is an Enum class for specifying different ingestion reports for ingestion isolation.
IngestionStats - Class in com.linkedin.davinci.stats
This class contains stats for store ingestion.
IngestionStats(VeniceServerConfig) - Constructor for class com.linkedin.davinci.stats.IngestionStats
 
IngestionStatsReporter - Class in com.linkedin.davinci.stats
This class is the reporting class for stats class IngestionStats.
IngestionStatsReporter(MetricsRepository, String) - Constructor for class com.linkedin.davinci.stats.IngestionStatsReporter
 
IngestionStatsReporter.IngestionStatsGauge - Class in com.linkedin.davinci.stats
 
IngestionStorageMetadata - Class in com.linkedin.venice.ingestion.protocol
 
IngestionStorageMetadata() - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Default constructor.
IngestionStorageMetadata(CharSequence, Integer, ByteBuffer, Integer) - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
All-args constructor.
ingestionTask - Variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
IngestionTaskCommand - Class in com.linkedin.venice.ingestion.protocol
 
IngestionTaskCommand() - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
Default constructor.
IngestionTaskCommand(CharSequence, Integer, Integer) - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
All-args constructor.
ingestionTaskName - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
IngestionTaskReport - Class in com.linkedin.venice.ingestion.protocol
 
IngestionTaskReport() - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Default constructor.
IngestionTaskReport(CharSequence, Integer, Long, Boolean, Boolean, Integer, CharSequence, List<ByteBuffer>, ByteBuffer, Integer) - Constructor for class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
All-args constructor.
ingestSSTFiles(RocksDB, List<ColumnFamilyHandle>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
init() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
During the initialization, we do the cluster discovery at first to find the real end point this client need to talk to, before initializing the serializer.
init() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
Initialize token buckets for all resources in the customized view repository.
init() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
 
init(Thread) - Method in class com.linkedin.alpini.base.concurrency.NamedThreadFactory
 
init(List<TehutiMetric>) - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
init(List<String>) - Method in interface com.linkedin.venice.acl.DynamicAccessController
Initialize access controller.
initChannel(C) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
This method will be called once the Channel was registered.
initChannel(C) - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
This method will be called once the Channel was registered.
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.handlers.BackgroundChannelHandler
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.handlers.ChunkedResponseHandler
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentCodec
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentDecoder
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.handlers.VIPRequestHandler
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.ssl.SslClientInitializer
 
initChannel(Channel) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
 
initChannel(SocketChannel) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerChannelInitializer
 
initChannel(SocketChannel) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionReportChannelInitializer
 
initChannel(SocketChannel) - Method in class com.linkedin.venice.listener.HttpChannelInitializer
 
initDuplicateKeyPrinter(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
No need to print out duplicate keys since duplicate keys are expected in Kafka topics.
initDuplicateKeyPrinter(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
initGrpcInterceptors() - Method in class com.linkedin.venice.listener.HttpChannelInitializer
SSL Certificates can only be accessed easily via Server Interceptors for gRPC, so we create our acls here We can create aclInterceptor list as these handlers are already present within
initGrpcRequestProcessor() - Method in class com.linkedin.venice.listener.HttpChannelInitializer
 
initHelixGroupSelector(HelixGroupSelector) - Method in class com.linkedin.venice.router.api.VeniceDelegateMode
 
initHelixGroupSelector(HelixGroupSelector) - Method in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
INITIAL - com.linkedin.alpini.netty4.handlers.VIPRequestHandler.State
 
initialize(String, String, Iterable<ByteBuffer>, VenicePartitionFinder, int, RouterStats<AggRouterHttpRequestStats>) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
Fill the router key map and the index2routerKey map.
INITIALIZE_PUSH_JOB - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
initializeExpectedChecksum() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
initializeMetrics(BasicRequest) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
initializePartitionReportStatus(int) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
This method is expected to be invoked when StoreIngestionTask is subscribing to a user partition.
initializeStatsForStore(String) - Method in class com.linkedin.venice.stats.AggServerQuotaTokenBucketStats
 
initialValue() - Method in class com.linkedin.alpini.base.misc.SoftThreadLocal
Returns the current thread's "initial value" for this thread-local variable.
initiateDataRecovery(String, String, int, String, boolean, Version) - Method in class com.linkedin.venice.controller.datarecovery.DataRecoveryManager
Initiate data recovery process by recreating the version, kafka topic, and Helix resources accordingly.
initiateDataRecovery(String, String, int, String, String, boolean, Optional<Version>) - Method in interface com.linkedin.venice.controller.Admin
Initiate data recovery for a store version given a source fabric.
initiateDataRecovery(String, String, int, String, String, boolean, Optional<Version>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
initiateDataRecovery(String, String, int, String, String, boolean, Optional<Version>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
initInputData(VeniceProperties) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
initKeySchema(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
Set up key schema for the given store.
initKeySchema(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
initKeySchema(String, String) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
Set up key schema for the given store
initKIFRepushDetails() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
initPartition(int) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
initProtocolMap() - Static method in class com.linkedin.venice.controller.kafka.protocol.serializer.AdminOperationSerializer
 
initReadRequestThrottler(RouterThrottler) - Method in class com.linkedin.venice.router.api.VeniceDelegateMode
 
initStorageCluster(String) - Method in interface com.linkedin.venice.controller.Admin
 
initStorageCluster(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Create and configure the Venice storage cluster with required properties in Helix and waits the resource's (partial) partition to appear in the external view.
initStorageCluster(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Initialize Venice storage cluster in Helix by: creating and configuring required properties in Helix. waiting resource's (partial) partition to appear in the external view. making sure admin Kafka topics is created. creating a Venice writer for the cluster.
initZstdConfig(int) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
initZstdConfig(int) - Method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
 
initZstdConfig(int) - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
 
InMemoryAdminTopicMetadataAccessor - Class in com.linkedin.venice.admin
In memory implementation of AdminTopicMetadataAccessor, should only be used for testing purposes.
InMemoryAdminTopicMetadataAccessor() - Constructor for class com.linkedin.venice.admin.InMemoryAdminTopicMetadataAccessor
 
InMemoryExecutionIdAccessor - Class in com.linkedin.venice.admin
In memory implementation of ExecutionIdAccessor, should only be used for testing purposes.
InMemoryExecutionIdAccessor() - Constructor for class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
InMemoryKafkaBroker - Class in com.linkedin.venice.unit.kafka
Used in unit tests in order to avoid spinning a full Kafka broker with network stack and disk IO.
InMemoryKafkaBroker(String) - Constructor for class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
 
InMemoryKafkaMessage - Class in com.linkedin.venice.unit.kafka
A single Kafka message, strongly typed for the types that Venice uses.
InMemoryKafkaMessage(KafkaKey, KafkaMessageEnvelope, PubSubMessageHeaders) - Constructor for class com.linkedin.venice.unit.kafka.InMemoryKafkaMessage
 
InMemoryLogAppender - Class in com.linkedin.venice.utils
 
InMemoryLogAppender(String, Filter, Layout<? extends Serializable>, boolean, Property[]) - Constructor for class com.linkedin.venice.utils.InMemoryLogAppender
 
InMemoryLogAppender.Builder - Class in com.linkedin.venice.utils
 
InMemoryOffsetManager - Class in com.linkedin.venice.offsets
In memory implementation of OffsetManager, should really only be used for tests
InMemoryOffsetManager() - Constructor for class com.linkedin.venice.offsets.InMemoryOffsetManager
 
inMemoryStorageEngine - Variable in class com.linkedin.davinci.utils.ChunkAssembler
 
InMemoryStorageEngine - Class in com.linkedin.davinci.store.memory
A simple non-persistent, in-memory store.
InMemoryStorageEngine(VeniceStoreVersionConfig) - Constructor for class com.linkedin.davinci.store.memory.InMemoryStorageEngine
 
InMemoryStorageEngine(String) - Constructor for class com.linkedin.davinci.store.memory.InMemoryStorageEngine
 
InMemoryStorageEngineFactory - Class in com.linkedin.davinci.store.memory
 
InMemoryStorageEngineFactory(VeniceServerConfig) - Constructor for class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
InMemoryStorageMetadataService - Class in com.linkedin.venice.offsets
In memory implementation of StorageMetadataService, should really only be used for tests
InMemoryStorageMetadataService() - Constructor for class com.linkedin.venice.offsets.InMemoryStorageMetadataService
 
InMemoryStoragePartition - Class in com.linkedin.davinci.store.memory
An in-memory hashmap implementation of a storage partition Assumptions: 1.No need to worry about synchronizing write/deletes as the model is based on a single writer.
InMemoryStoragePartition(Integer) - Constructor for class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
INPUT_DATA_SCHEMA_VALIDATION_FAILED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
INPUT_PATH_LAST_MODIFIED_TIME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
INPUT_PATH_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
inputDataInfo - Variable in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
InputDataInfo(long, int, boolean, long) - Constructor for class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
 
InputDataInfo(long, int, boolean, long, boolean) - Constructor for class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
 
inputDataInfoProvider - Variable in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
InputDataInfoProvider - Interface in com.linkedin.venice.hadoop
This interface lets users get input data information
InputDataInfoProvider.InputDataInfo - Class in com.linkedin.venice.hadoop
A POJO that contains input data information (schema information and input data file size)
inputDataSchema - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
inputDataSchemaString - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
inputDirectory - Variable in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
inputFileDataSize - Variable in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
Total input Data size in all files
inputFileDataSize - Variable in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
inputFileDataSizeInBytes - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
inputHasRecords - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
InputStorageQuotaTracker - Class in com.linkedin.venice.hadoop
This class is used to keep track of store storage quota and storage overhead ratio and check whether the total input data size exceeds the quota
InputStorageQuotaTracker(Long) - Constructor for class com.linkedin.venice.hadoop.InputStorageQuotaTracker
 
inputStream() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
inputURI - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
insert(String, StoreInfo) - Method in class com.linkedin.venice.meta.StoreDataAudit
 
insert(K, V) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
insert(K, V) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Associates the value with the key in this cache.
Instance - Class in com.linkedin.venice.meta
Class defines the Instance in Venice.
Instance(String, String, int) - Constructor for class com.linkedin.venice.meta.Instance
 
Instance(String, String, int, int) - Constructor for class com.linkedin.venice.meta.Instance
 
INSTANCE - Static variable in exception com.linkedin.alpini.base.misc.Http2TooManyStreamsException
 
INSTANCE - Static variable in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
INSTANCE - Static variable in class com.linkedin.alpini.netty4.handlers.ElideDuplicateHeadersHandler
 
INSTANCE - Static variable in class com.linkedin.alpini.netty4.handlers.Http2ExceptionHandler
 
INSTANCE - Static variable in class com.linkedin.alpini.netty4.handlers.InboundContentDebugHandler.HttpDecodeResult
 
INSTANCE - Static variable in class com.linkedin.alpini.netty4.misc.RandomEventExecutorChooserFactory
 
INSTANCE - Static variable in class com.linkedin.alpini.netty4.misc.StickyEventExecutorChooserFactory
 
INSTANCE - Static variable in class com.linkedin.davinci.schema.merge.AvroCollectionElementComparator
 
INSTANCE - Static variable in class com.linkedin.davinci.storage.chunking.GenericChunkingAdapter
 
INSTANCE - Static variable in class com.linkedin.davinci.storage.chunking.GenericRecordChunkingAdapter
 
INSTANCE - Static variable in class com.linkedin.davinci.storage.chunking.RawBytesChunkingAdapter
 
INSTANCE - Static variable in class com.linkedin.venice.pubsub.PubSubPositionFactory
 
INSTANCE - Static variable in class com.linkedin.venice.utils.SystemTime
 
INSTANCE_ID - Static variable in class com.linkedin.venice.ConfigKeys
A unique id that can represent this instance
INSTANCE_VIEW - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
InstanceHealthMonitor - Class in com.linkedin.venice.fastclient.meta
The class is used to measure the healthiness about the cluster the store belongs to.
InstanceHealthMonitor(ClientConfig) - Constructor for class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
 
instanceIdToUrl(String) - Static method in class com.linkedin.venice.utils.HelixUtils
Convert a replica's instance ID to its URL.
instanceName - Variable in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
instances - Variable in class com.linkedin.venice.pushstatus.PushStatusValue
 
InstanceStatus - Enum in com.linkedin.venice.meta
Status of the instance in Venice cluster.
InstanceStatusDecider - Class in com.linkedin.venice.controller
This class is not Thread-safe.
InstanceStatusDecider() - Constructor for class com.linkedin.venice.controller.InstanceStatusDecider
 
instantiateManifestPut() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveProducerCallback
 
instantiateManifestPut() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
instantiateRmdChunkPut() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveProducerCallback
 
instantiateRmdChunkPut() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
instantiateValueChunkPut() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveProducerCallback
 
instantiateValueChunkPut() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
InstrumentedBootstrap - Class in io.netty.bootstrap
Because various netty methods and classes have been declared as final, we construct this pile of foo in order to be able to instrument the InstrumentedBootstrap.connect() method invocation.
InstrumentedBootstrap(CallTracker) - Constructor for class io.netty.bootstrap.InstrumentedBootstrap
 
InstrumentedBootstrap(InstrumentedBootstrap) - Constructor for class io.netty.bootstrap.InstrumentedBootstrap
 
InstrumentedBootstrap(Function<SocketAddress, CallTracker>) - Constructor for class io.netty.bootstrap.InstrumentedBootstrap
 
InstrumentibleEventExecutor - Class in com.linkedin.alpini.netty4.misc
 
InstrumentibleEventExecutor(EventExecutorGroup) - Constructor for class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
InstrumentibleEventExecutor.Completion - Class in com.linkedin.alpini.netty4.misc
 
int_field - Variable in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
INT_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
INT_TO_STRING_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
INT16 - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
INT32 - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
INT64 - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
INT8 - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class com.linkedin.venice.acl.handler.StoreAclHandler
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class com.linkedin.venice.listener.ServerAclHandler
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class com.linkedin.venice.listener.ServerStoreAclHandler
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class com.linkedin.venice.listener.VerifySslHandler
 
INTERNAL_ERROR - Static variable in class com.linkedin.venice.grpc.GrpcErrorCodes
 
InternalAvroSpecificSerializer<SPECIFIC_RECORD extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.serialization.avro
Serializer for translating a versioned protocol of Avro records.
InternalAvroSpecificSerializer(AvroProtocolDefinition) - Constructor for class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
InternalAvroSpecificSerializer(AvroProtocolDefinition, Integer) - Constructor for class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
InternalAvroSpecificSerializer(AvroProtocolDefinition, Integer, BiConsumer<Integer, Schema>) - Constructor for class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
InternalAvroStoreClient<K,​V> - Class in com.linkedin.venice.client.store
This class includes some necessary functions to deal with certain metric-handling activities that only the client implementation can be aware of.
InternalAvroStoreClient<K,​V> - Class in com.linkedin.venice.fastclient
All the internal implementations of different tiers should extend this class.
InternalAvroStoreClient() - Constructor for class com.linkedin.venice.client.store.InternalAvroStoreClient
 
InternalAvroStoreClient() - Constructor for class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
internalDrainBufferedRecordsFromTopicPartition(PubSubTopicPartition, int, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
internalGetFieldAccessorTable() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
internalGetFieldAccessorTable() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
internalGetFieldAccessorTable() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
internalGetFieldAccessorTable() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
internalHandle(Request, T) - Method in class com.linkedin.venice.controller.server.VeniceRouteHandler
provides a common way to write a handler function for an HTTP request and fill in the HTTP response.
internalHasNext() - Method in class com.linkedin.venice.utils.collections.ArrayBackedNullSkippingIterator
 
internalHasNext() - Method in class com.linkedin.venice.utils.collections.NullSkippingIteratorWrapper
 
internalLevel - Variable in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
internalNext() - Method in class com.linkedin.venice.utils.collections.ArrayBackedNullSkippingIterator
 
internalNext() - Method in class com.linkedin.venice.utils.collections.NullSkippingIteratorWrapper
 
internalPoll(long, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
internalPoll(long, String, boolean) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
internalSeek(Set<Integer>, PubSubTopic, VeniceChangelogConsumerImpl.SeekFunction) - Method in class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
internalSeek(Set<Integer>, PubSubTopic, VeniceChangelogConsumerImpl.SeekFunction) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
internalSeekToTail(Set<Integer>, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
internalSeekToTimestamps(Map<Integer, Long>, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
internalServerError() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
internalServerError() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
internalSubscribe(Set<Integer>, PubSubTopic) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
InternalTransportClient - Class in com.linkedin.venice.fastclient.transport
Abstract class for Fast-Client transport layer implementation, and this layer is mostly decided which methods need to be implemented at different stages.
InternalTransportClient() - Constructor for class com.linkedin.venice.fastclient.transport.InternalTransportClient
 
internalWrite(Schema, Object, Encoder) - Method in interface org.apache.avro.generic.DeterministicMapOrderDatumWriter
 
internalWrite(Schema, Object, Encoder) - Method in class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
 
internalWrite(Schema, Object, Encoder) - Method in class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
 
interval - Variable in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
INTERVAL - com.linkedin.venice.Arg
 
INTERVAL_UNSET - Static variable in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
INVALID - Static variable in class com.linkedin.venice.schema.GeneratedSchemaID
 
INVALID_CONFIG - com.linkedin.venice.exceptions.ErrorType
 
INVALID_CONFIG - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
INVALID_INPUT_FILE - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
INVALID_SCHEMA - com.linkedin.venice.exceptions.ErrorType
 
INVALID_SCHEMA - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
INVALID_VALUE_SCHEMA_ID - Static variable in class com.linkedin.venice.schema.SchemaData
 
invalidate(K) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
invalidate(K) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Discards any cached value for the key.
invalidateCache(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Invalidate the cache for the given topic and all its partitions.
invalidateTopicManagerCaches(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerRepository
Invalidates the cache for the given PubSub topic across all TopicManagers in the repository.
InvalidConfigException - Exception in com.linkedin.alpini.consts.config
Forked from com.linkedin.databus.core.util @ r293057
InvalidConfigException(String) - Constructor for exception com.linkedin.alpini.consts.config.InvalidConfigException
 
InvalidConfigException(String, Throwable) - Constructor for exception com.linkedin.alpini.consts.config.InvalidConfigException
 
InvalidConfigException(Throwable) - Constructor for exception com.linkedin.alpini.consts.config.InvalidConfigException
 
InvalidDatabaseNameException - Exception in com.linkedin.venice.store.exception
 
InvalidDatabaseNameException(PersistenceType, String) - Constructor for exception com.linkedin.venice.store.exception.InvalidDatabaseNameException
 
InvalidKeySchemaPartitioner - Class in com.linkedin.venice.partitioner
Implementation of the VenicePartitioner class for test purpose.
InvalidKeySchemaPartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.partitioner.InvalidKeySchemaPartitioner
 
InvalidVeniceSchemaException - Exception in com.linkedin.venice.exceptions
 
InvalidVeniceSchemaException(String) - Constructor for exception com.linkedin.venice.exceptions.InvalidVeniceSchemaException
 
InvalidVeniceSchemaException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.InvalidVeniceSchemaException
 
inViableWithError(RepushViabilityInfo.Result) - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
inViableWithResult(RepushViabilityInfo.Result) - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
invokeAll(Collection<? extends Callable<T>>) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
invokeAny(Collection<? extends Callable<T>>) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
invokeNextHandler(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
 
io.netty.bootstrap - package io.netty.bootstrap
 
io.netty.channel - package io.netty.channel
 
io.netty.handler.codec - package io.netty.handler.codec
 
io.netty.handler.codec.http - package io.netty.handler.codec.http
 
io.netty.handler.codec.http2 - package io.netty.handler.codec.http2
 
io.netty.handler.timeout - package io.netty.handler.timeout
 
IOUtils - Enum in com.linkedin.alpini.io
 
ioWorkerPoolBuilder(Class<POOL_TYPE>, Function<Executor, POOL_TYPE>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
ioWorkerPoolBuilder(Class<POOL_TYPE>, Function<Executor, POOL_TYPE>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
ioWorkerPoolSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
ioWorkerPoolSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
IS_MANAGED - Static variable in class com.linkedin.davinci.config.StoreBackendConfig
 
IS_PARTITION_CONSUMING - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
IS_STORE_VERSION_READY_FOR_DATA_RECOVERY - com.linkedin.venice.controllerapi.ControllerRoute
 
IS_SYSTEM_STORE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
IS_WRITE_COMPUTE_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
isAccessControlled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isAccessControlled() - Method in interface com.linkedin.venice.meta.Store
 
isAccessControlled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isAccessControlled() - Method in class com.linkedin.venice.meta.SystemStore
 
isAccessControlled() - Method in class com.linkedin.venice.meta.ZKStore
Deprecated.
The store level accessControlled flag is no longer valid to be used to skip ACL checks.
isAclEnabled() - Method in class com.linkedin.venice.controller.server.AbstractRoute
 
isActiveActiveReplicationEnabled() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isActiveActiveReplicationEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isActiveActiveReplicationEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.meta.VersionImpl
 
isActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isActiveActiveReplicationEnabledAsDefaultForBatchOnly() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isActiveActiveReplicationEnabledAsDefaultForHybrid() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isActiveActiveReplicationEnabledInAllRegion(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
Returns true if A/A replication is enabled in all child controller and parent controller.
isActiveActiveReplicationEnabledInAllRegion(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isActiveActiveReplicationEnabledInAllRegion(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isAdminHelixMessagingChannelEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isAdminTopic(String) - Static method in class com.linkedin.venice.controller.kafka.AdminTopicUtils
 
isAdminTopic(String) - Static method in enum com.linkedin.venice.pubsub.api.PubSubTopicType
 
isAdminTopicConsumptionEnabled(String) - Method in interface com.linkedin.venice.controller.Admin
Return whether the admin consumption task is enabled for the passed cluster.
isAdminTopicConsumptionEnabled(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isAdminTopicRemoteConsumptionEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isAggregated(I) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Returns true if and only if the specified message is already aggregated.
isAggregated(HttpObject) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
isAggregated(HttpObject) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
isAllowGeneratingSelfSignedCertificate() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
isAllowListUser(Request) - Method in class com.linkedin.venice.controller.server.AbstractRoute
Check whether the user is within the admin users allowlist.
isAllowlistUsers(X509Certificate, String, String) - Method in interface com.linkedin.venice.acl.AccessController
Check whether the client is the allowlist admin users.
isAssembledMultiChunkLargeValue() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
isAssembledMultiChunkLargeValue() - Method in class com.linkedin.venice.listener.StatsHandler
 
isAsyncStartEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isAtomicFlushEnabled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isATopicThatIsVersioned(String) - Static method in interface com.linkedin.venice.meta.Version
Determines if the the inputted topic is a topic which is versioned.
isAutoCreateDataPath() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isAutoMaterializeDaVinciPushStatusSystemStoreEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isAutoMaterializeMetaSystemStoreEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isAutoTunedRateLimiterEnabled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isAvro - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isBackupVersionMetadataFetchBasedCleanupEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isBackupVersionRetentionBasedCleanupEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isBadState() - Method in class com.linkedin.venice.d2.D2HealthChecker
 
isBatch() - Method in enum com.linkedin.venice.meta.Version.PushType
 
isBatchGetRouterCacheEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isBatchOnly() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isBatchOrStreamReprocessing() - Method in enum com.linkedin.venice.meta.Version.PushType
 
ISBATCHREQUEST_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
isBatchUpdate() - Method in enum com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
isBlobTransferEnabled() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
isBlobTransferEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isBlobTransferEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isBlobTransferEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isBlobTransferEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isBlobTransferEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isBlobTransferEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isBlobTransferEnabled() - Method in class com.linkedin.venice.meta.VersionImpl
 
isBlobTransferEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isBlocking() - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
isBootstrapCompleted(VersionStatus) - Static method in enum com.linkedin.venice.meta.VersionStatus
Check if the Version has completed the bootstrap.
isBusyAutoReadDisable() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
isBusyAutoReadDisable(Router) - Static method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
isCacheEnabled() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
isCallComplete(long) - Method in interface com.linkedin.alpini.netty4.pool.Http2PingCallListener
 
isCallComplete(long) - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
isCancellable() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
isCancelled() - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
isCancelled() - Method in class com.linkedin.alpini.base.concurrency.impl.CancelledAsyncFuture
Always returns true.
isCancelled() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Returns true if this task was cancelled before it completed normally.
isCancelled() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Returns true if this task was cancelled before it completed normally.
isCancelled() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
isCheckpointingSupported() - Method in enum com.linkedin.venice.kafka.validation.checksum.CheckSumType
 
isCheckQuotaBeforeRecording() - Method in class com.linkedin.venice.throttle.EventThrottler
 
isChildControllerAdminTopicConsumptionEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isChildControllerAdminTopicConsumptionEnabled() - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
isChunk - Variable in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
This is used to reliably disambiguate between chunks and non-chunks.
isChunked - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isChunked() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isChunked() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
isChunkingEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isChunkingEnabled() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
isChunkingEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isChunkingEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isChunkingEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isChunkingEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isChunkingEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isChunkingEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isChunkingEnabled() - Method in class com.linkedin.venice.meta.VersionImpl
 
isChunkingEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isChunkingEnabled() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
isClonedStoreOnline(ControllerClient, ControllerClient, String) - Static method in class com.linkedin.venice.AdminTool
 
isClosed() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolWithStats
 
isClosed() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
isClosed() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
isClosed() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
isClosed() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
isClosed() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
isClosed() - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
 
isClosing() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
isClosing() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
isClosing() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
isClosing() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
isClusterInGrandCluster(String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Check if the grand cluster managed by HaaS controllers is aware of the given cluster.
isClusterInGrandCluster(String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
isClusterValid(String) - Method in interface com.linkedin.venice.controller.Admin
 
isClusterValid(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Test if a cluster is valid (in Helix cluster list).
isClusterValid(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Test if a cluster is valid (in Helix cluster list).
isClusterWipeAllowed() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isClusterWipeAllowed(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isCompatibleEncoding(CharSequence, CharSequence) - Static method in class com.linkedin.alpini.netty4.compression.CompressionUtils
Test if the specific encoding is permitted by the provided list of encodings as used in HTTP Accepts-Encoding header.
isComplete() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isComplete() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
isCompleted() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
isCompletionReported() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isCompressionEnabled() - Method in enum com.linkedin.venice.compression.CompressionStrategy
 
isComputeFastAvroEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isComputeFastAvroEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isConcurrentInitRoutinesEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isConcurrentTopicDeleteRequestsEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isConcurrentTopicDeleteRequestsEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isConfiguredHttp2Connection(Channel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Check whether the channel is a http2 connection that has been configured.
isConnected() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
isConscryptAvailable() - Static method in class com.linkedin.venice.utils.SslUtils
Check whether openssl provider is available or not.
isContentAlwaysEmpty(H) - Method in class io.netty.handler.codec.http.EspressoHttpObjectEncoder
Determine whether a message has a content or not.
isContentAlwaysEmpty(HttpMessage) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
isContentAlwaysEmpty(HttpResponse) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Encoder
 
isContentLengthInvalid(HttpMessage, int) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
isContentLengthInvalid(HttpMessage, int) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
isContentLengthInvalid(S, int) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Determine if the message start's content length is known, and if it greater than maxContentLength.
isContentMessage(I) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Returns true if and only if the specified message is a content message.
isContentMessage(HttpObject) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
isContentMessage(HttpObject) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
isControllerClusterLeaderHAAS() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isControllerEnforceSSLOnly() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isControllerEnforceSSLOnly() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isControllerInAzureFabric() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isControllerSchemaValidationEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isControllerSSLEnabled() - Method in class com.linkedin.venice.SSLConfig
 
isControlMessage() - Method in class com.linkedin.venice.message.KafkaKey
 
isCoreWorkDone - Variable in class com.linkedin.venice.datarecovery.Command.Result
 
isCoreWorkDone() - Method in class com.linkedin.venice.datarecovery.Command.Result
 
isCoreWorkDone() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
 
isCurrentVersion - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isCurrentVersion(String, ReadOnlyStoreRepository) - Static method in class com.linkedin.venice.utils.Utils
 
isD2Routing() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isDatabaseChecksumVerificationEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isDatabaseMemoryStatsEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isDataRecovery - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isDataRecoveryComplete - Variable in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Whether or not data recovery is complete.
isDataRecoveryComplete() - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
 
isDataRecoveryComplete() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
isDataRecoveryCompleted() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isDaVinciClient - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isDaVinciClient() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isDaVinciClient() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
isDaVinciClient() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
isDaVinciPushStatusEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isDaVinciPushStatusScanEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
isDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isDaVinciPushStatusStoreEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isDebugEnabled() - Method in class com.linkedin.alpini.log.FastLog
 
isDebugEnabled() - Method in class com.linkedin.alpini.log.FastLogContext
 
isDebugEnabled() - Method in class com.linkedin.alpini.log.FastLogger
 
isDebugEnabled() - Method in interface com.linkedin.alpini.log.FastLogMBean
 
isDebugEnabled(Marker) - Method in class com.linkedin.alpini.log.FastLogger
 
isDebugLoggingEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isDecodingRequest() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
 
isDecodingRequest() - Method in class com.linkedin.alpini.netty4.handlers.HttpContentMultiPartDecode
 
isDecodingRequest() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
isDecodingRequest() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
 
isDecompressOnClient() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isDedicatedConsumerPoolForAAWCLeaderEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isDedicatedDrainerQueueEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isDeferredWrite() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isDeferredWrite() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
isDelayStart() - Method in class com.linkedin.venice.d2.D2Server
 
isDelayStart() - Method in class com.linkedin.venice.d2.D2ServerManager
 
isDeleting() - Method in class com.linkedin.venice.meta.StoreConfig
 
isDerivedSchema() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
isDeterminedStatus(ExecutionStatus) - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
Some of the statuses are like watermark.
isDifferent(UpdateStoreQueryParams) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
isDirectBufferPooled() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
isDisableParentRequestTopicForStreamPushes() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isDisableParentRequestTopicForStreamPushes() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isDisconnected() - Method in class com.linkedin.venice.helix.CachedResourceZkStateListener
 
isDiskFull(long) - Method in class com.linkedin.venice.utils.DiskUsage
Each time you write bytes to the disk, call this method.
isDiskHealthCheckServiceEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isDiskHealthy() - Method in class com.linkedin.davinci.storage.DiskHealthCheckService
 
isDnsCacheEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isDone() - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
isDone() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Returns true if this task completed.
isDone() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Returns true if this task completed.
isDone() - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor.TimeoutFuture
Test if the task has been completed.
isDone() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
isDoNotStart() - Method in class com.linkedin.venice.d2.D2ServerManager
 
isDualReadEnabled() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
isDuplicateKeyAllowed - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isDVCIngestionError() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isEarlyDeleteBackUpEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isEarlyThrottleEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isEmpty() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
isEmpty() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
isEmpty() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Determine if this instance has 0 length.
isEmpty() - Method in interface com.linkedin.alpini.base.misc.Headers
 
isEmpty() - Method in class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
 
isEmpty() - Method in class com.linkedin.alpini.base.queuing.QOSBasedQueue
 
isEmpty() - Method in class com.linkedin.alpini.base.queuing.QOSFCFSQueue
 
isEmpty() - Method in interface com.linkedin.alpini.base.queuing.SimpleQueue
Checks if queue is empty.
isEmpty() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
isEmpty() - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
isEmpty() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
isEmpty() - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns true if this map contains no key-value mappings.
isEmpty() - Method in class com.linkedin.venice.hadoop.FilterChain
 
isEmpty() - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
isEmpty() - Method in class com.linkedin.venice.utils.ComplementSet
 
isEmpty() - Method in class com.linkedin.venice.utils.SparseConcurrentList
N.B.: If the list is only populated with null entries, this function will return true.
isEmpty() - Method in class com.linkedin.venice.utils.VeniceProperties
 
isEmpty() - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Are there pending buffers in the queue.
isEnableBatchPushFromAdminInChildController() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isEnableBatchPushFromAdminInChildController() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isEnabled(Level) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabled(Level, Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
isEnabledFor(Logger, Level) - Static method in class com.linkedin.alpini.consts.Level
 
isEnableDisabledReplicaEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isEnableNearlinePushSSLAllowlist() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isEnableOfflinePushSSLAllowlist() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isEnableParallelBatchGet() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isEnablePartialUpdateForHybridActiveActiveUserStores() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isEnablePartialUpdateForHybridNonActiveActiveUserStores() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isEnableReads() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isEnableReads() - Method in interface com.linkedin.venice.meta.Store
 
isEnableReads() - Method in class com.linkedin.venice.meta.SystemStore
System stores are the internal stores, and even the corresponding user store is not readable, and the internal system stores could be readable, which is controlled by the SystemStore.zkSharedStore.
isEnableReads() - Method in class com.linkedin.venice.meta.ZKStore
 
isEnableRetryRequestAlwaysUseADifferentHost() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
isEnableSSL() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
isEnableStackTraceResponseForException() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
isEnableStoreReads() - Method in class com.linkedin.venice.meta.StoreInfo
 
isEnableStoreWrites() - Method in class com.linkedin.venice.meta.StoreInfo
Whether the store is enableStoreWrites, a enableStoreWrites store cannot have new versions pushed
isEnableWriteCompute() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
isEnableWrites() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isEnableWrites() - Method in interface com.linkedin.venice.meta.Store
 
isEnableWrites() - Method in class com.linkedin.venice.meta.SystemStore
System stores are the internal stores, and even the corresponding user store is not writable, and the internal system stores could be writable, which is controlled by the SystemStore.zkSharedStore.
isEnableWrites() - Method in class com.linkedin.venice.meta.ZKStore
 
isEnd() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
isEnded() - Method in class com.linkedin.venice.kafka.validation.Segment
 
isEndOfBootstrap() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
isEndOfBootstrap() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
 
isEndOfBootstrap() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
isEndOfPushReceived() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isEndOfPushReceived() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
isEnforcingSecureOnly() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isEqual(D2Server) - Method in class com.linkedin.venice.d2.D2Server
Compare D2Server to another one to check quality.
isError() - Method in class com.linkedin.davinci.listener.response.AdminResponse
 
isError() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
isError() - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
 
isError() - Method in class com.linkedin.davinci.listener.response.TopicPartitionIngestionContextResponse
 
isError() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
Starting with Jackson 1.9, if this is the only annotation: JsonIgnore associated with a property, it will also cause the whole property to be ignored.
isError() - Method in class com.linkedin.venice.datarecovery.Command.Result
 
isError() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
 
isError() - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
isError() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isError(ExecutionStatus) - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isError(String) - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isErrorEnabled() - Method in class com.linkedin.alpini.log.FastLogger
 
isErrorEnabled(Marker) - Method in class com.linkedin.alpini.log.FastLogger
 
isErrorLeaderReplicaFailOverEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isErrorReported() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isExtraReplica(ReadOnlyStoreRepository, Replica, List<Instance>) - Static method in class com.linkedin.venice.utils.Utils
When Helix thinks some host is overloaded or a new host joins the cluster, it might move some replicas from one host to another.
isFactoryInterface(Class<?>) - Static method in class com.linkedin.alpini.base.registry.ResourceRegistry
Checks if the supplied class is a permissable factory class.
isFailOpen() - Method in interface com.linkedin.venice.acl.DynamicAccessController
Use this method to determine if clients will be granted access to a resource when the corresponding ACL of the resource is missing.
isFatalEnabled() - Method in class com.linkedin.alpini.log.FastLogger
 
isFatalEnabled(Marker) - Method in class com.linkedin.alpini.log.FastLogger
 
isFinalBlock() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
isForceClusterDiscoveryAtStartTime() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isFormatB64(String) - Static method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
isFound() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
isFound() - Method in class com.linkedin.venice.listener.response.StorageResponseObject
 
isFullResponse() - Method in interface com.linkedin.venice.client.store.streaming.VeniceResponseMap
Whether the result is a full response or not.
isFullResponse() - Method in class com.linkedin.venice.client.store.streaming.VeniceResponseMapImpl
 
isFutureVersion() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isFutureVersion(String, int) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
isFutureVersion(String, ReadOnlyStoreRepository) - Static method in class com.linkedin.venice.utils.Utils
 
isFutureVersionETLEnabled() - Method in interface com.linkedin.venice.meta.ETLStoreConfig
 
isFutureVersionETLEnabled() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
isGreaterOrEqual(Level) - Method in class com.linkedin.alpini.consts.Level
 
isGrpcEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isHandlingOversizedMessage() - Method in class io.netty.handler.codec.EspressoMessageAggregator
Deprecated.
This method will be removed in future releases.
isHealthy() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
isHealthy() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
isHealthy() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
isHealthy() - Method in interface com.linkedin.alpini.netty4.pool.ManagedChannelPool
 
isHealthy(Channel) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
isHealty() - Method in class com.linkedin.alpini.netty4.handlers.VIPRequestHandler
 
isHelixHybridStoreQuotaEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isHelixHybridStoreQuotaEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isHelixTriggeredAction() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
isHostHealthy(Instance, String) - Method in class com.linkedin.venice.router.api.VeniceHostHealth
 
isHostHealthy(H, String) - Method in interface com.linkedin.alpini.router.api.HostHealthMonitor
To check if a host is healthy/responsive.
isHostHealthy(H, String) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
To check if a host is healthy/responsive.
isHttp2InboundEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isHttp2InboundEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isHttp2MultiplexPipeline(boolean, ChannelPipeline) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
isHttp2ParentChannelPipeline(ChannelPipeline) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
isHttp2Pipeline(ChannelPipeline) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Deprecated.
isHttpasyncclientConnectionWarmingEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isHttpClient5Http2Enabled() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isHttpClient5SkipCipherCheck() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isHttpClientOpensslEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isHttpGet(String) - Static method in class com.linkedin.venice.router.utils.VeniceRouterUtils
 
isHttpPost(String) - Static method in class com.linkedin.venice.router.utils.VeniceRouterUtils
 
isHttps() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isHybrid() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isHybrid() - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
isHybrid() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isHybrid() - Method in interface com.linkedin.venice.meta.Store
 
isHybrid() - Method in class com.linkedin.venice.meta.SystemStore
 
isHybrid() - Method in class com.linkedin.venice.meta.ZKStore
 
isHybridFollower(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
isHybridFollower(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isHybridMode() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isHybridQuotaEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isHybridStoreDiskQuotaEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isIdleConnectionToServerCleanupEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isIncremental() - Method in enum com.linkedin.venice.meta.Version.PushType
 
isIncrementalPush - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isIncrementalPushEnabled - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether the store is incremental push enabled.
isIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isIncrementalPushEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isIncrementalPushEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.VersionImpl
 
isIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isIncrementalPushStatus(int) - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isIncrementalPushStatus(ExecutionStatus) - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isInfoEnabled() - Method in class com.linkedin.alpini.log.FastLogger
 
isInfoEnabled(Marker) - Method in class com.linkedin.alpini.log.FastLogger
 
isIngestionMlockEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isIngestionTaskActive() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isInitialized() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
We only ever expect the initialized value to flip from false to true, but that initialization might happen in a different thread.
isInitialized() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
isInitialized() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
isInitialized() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
isInitialized() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
isInitiated() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
isInputBufferFull() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
isInputBufferFull() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
isInPutOnlyState() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
isInstanceAlive(Instance) - Method in class com.linkedin.venice.helix.HelixLiveInstanceMonitor
 
isInstanceAlive(Instance) - Method in interface com.linkedin.venice.meta.LiveInstanceMonitor
Check whether current instance is alive or not.
isInstanceAlive(String, String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
isInstanceBlocked(String) - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
If an instance is blocked, it won't be considered for new requests until the requests are closed either in a proper manner or closed by {@link #trackHealthBasedOnRequestToInstance#timeoutFuture}
isInstanceHealthy(String) - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
If an instance is marked unhealthy, this instances will be retried again continuously to know if that instance comes back up and start serving requests.
isInstanceInAllowlist(String, String) - Method in interface com.linkedin.venice.helix.AllowlistAccessor
Judge whether the given helix nodeId is in the allowlist or not.
isInstanceInAllowlist(String, String) - Method in class com.linkedin.venice.helix.ZkAllowlistAccessor
Judge whether the given helix nodeId is in the allowlist or not.
isInstanceReadyToServe(String) - Method in class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
 
isInstanceReadyToServe(String) - Method in interface com.linkedin.venice.router.httpclient.StorageNodeClient
 
isInstanceRemovable(String, String, List<String>, boolean) - Method in interface com.linkedin.venice.controller.Admin
Assuming all hosts identified by lockedNodes and their corresponding resources are unusable, is the given instance able to be removed out from the given cluster.
isInstanceRemovable(String, String, List<String>, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isInstanceRemovable(String, String, List<String>, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
isInvoked() - Method in class com.linkedin.venice.pubsub.adapter.PubSubProducerCallbackSimpleImpl
 
isIsolated() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
isIsolatedIngestion - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isIsolatedIngestion() - Method in class com.linkedin.davinci.DaVinciBackend
 
isJobStatus() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isKafkaConsumerOffsetCollectionEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isKafkaInternalTopic(String) - Static method in class com.linkedin.venice.controller.kafka.AdminTopicUtils
 
isKafkaLogCompactionForHybridStoresEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isKafkaProtocolValid(String) - Static method in class com.linkedin.venice.utils.KafkaSSLUtils
Right now, Venice only supports two Kafka protocols: SecurityProtocol.PLAINTEXT SecurityProtocol.SSL
isKafkaSSLProtocol(String) - Static method in class com.linkedin.venice.utils.KafkaSSLUtils
 
isKafkaSSLProtocol(SecurityProtocol) - Static method in class com.linkedin.venice.utils.KafkaSSLUtils
 
isKeyValueProfilingEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isKeyValueProfilingEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isKMERegistrationFromMessageHeaderEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isKMERegistrationFromMessageHeaderEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isLastAttempt(HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
isLastContentMessage(C) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Returns true if and only if the specified message is the last content message.
isLastContentMessage(HttpContent) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
isLastContentMessage(HttpContent) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
isLastVersionSwapMessageFromRealTimeTopic - Variable in class com.linkedin.venice.kafka.protocol.VersionSwap
Flag to indicate this version swap message in version topic is triggered by the last version swap in real time topic the leader server has received.
isLatchReleased - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether transition latch is released
isLatchReleased() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isLeader() - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
Test if current state is HelixState.LEADER_STATE.
isLeader() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
isLeader(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
isLeaderCompleted() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isLeaderCompleteStateCheckInFollowerEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isLeaderControllerFor(String) - Method in interface com.linkedin.venice.controller.Admin
Check if this controller itself is the leader controller for a given cluster or not.
isLeaderControllerFor(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isLeaderControllerFor(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isLeaderControllerOfControllerCluster() - Method in interface com.linkedin.venice.controller.Admin
This function can be used to perform cluster-wide operations which need to be performed by a single process only in the whole cluster.
isLeaderControllerOfControllerCluster() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
This function is used to detect whether current node is the leader controller of controller cluster.
isLeaderControllerOfControllerCluster() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isLeaderFollowerModelEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isLeaderFollowerModelEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isLeaderSubPartition(int) - Method in class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
 
isLeakedResourceCleanupEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isLiveConfigBasedKafkaThrottlingEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isLiveInstance(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
isLiveInstance(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
 
isLiveInstance(String, String, SafeHelixManager) - Static method in class com.linkedin.venice.utils.HelixUtils
 
isLiveUpdateSuppressionEnabled() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
isLogCompacted() - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
isLongTailRetryAllowedForNewRoute() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
isLongTailRetryAllowedForNewRoute() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
isLongTailRetryEnabledForBatchGet() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
isLongTailRetryEnabledForCompute() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
isLongTailRetryEnabledForSingleGet() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
isManaged() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
isManaged() - Method in class com.linkedin.davinci.config.StoreBackendConfig
 
isManaged() - Method in class com.linkedin.davinci.StoreBackend
 
isMaxCapacityProtectionEnabled() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
isMaxCapacityProtectionEnabled() - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
isMaxCapacityProtectionEnabled() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
 
isMetadataConnWarmupEnabled() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
isMetadataPartition(int) - Static method in class com.linkedin.davinci.store.AbstractStorageEngine
 
isMetadataRequest() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
isMetaStoreShadowReadEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isMetricsEmissionEnabled() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isMigrating - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether or not the store is in the process of migration
isMigrating() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isMigrating() - Method in interface com.linkedin.venice.meta.Store
 
isMigrating() - Method in class com.linkedin.venice.meta.StoreInfo
 
isMigrating() - Method in class com.linkedin.venice.meta.SystemStore
The system store will be migrated together with the corresponding Venice store.
isMigrating() - Method in class com.linkedin.venice.meta.ZKStore
 
isMigrationDuplicateStore() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isMigrationDuplicateStore() - Method in interface com.linkedin.venice.meta.Store
 
isMigrationDuplicateStore() - Method in class com.linkedin.venice.meta.StoreInfo
 
isMigrationDuplicateStore() - Method in class com.linkedin.venice.meta.SystemStore
 
isMigrationDuplicateStore() - Method in class com.linkedin.venice.meta.ZKStore
 
isMisroutedStoreVersion() - Method in class com.linkedin.venice.listener.response.HttpShortcutResponse
 
isMisroutedStoreVersion() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
isMissingAssignedPartitions() - Method in class com.linkedin.venice.meta.PartitionAssignment
 
isMultipart() - Method in interface com.linkedin.alpini.base.misc.HeaderUtils.ContentType
 
isNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isNativeReplicationEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isNativeReplicationEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.VersionImpl
 
isNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isNativeReplicationEnabledAsDefaultForBatchOnly() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isNativeReplicationEnabledAsDefaultForHybrid() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isNativeReplicationEnabledForBatchOnly() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isNativeReplicationEnabledForHybrid() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isNearlineMetricsRecordingValid(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
check to ignore calculating latency from pubsub broker to ready to serve for messages that are getting caught up from previous pushes.
isNewMedataRepositoryAdopted() - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
isNewNoBucketResource(String) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
isNewRequest() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
isNewSchemaCompatible(SchemaEntry, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.schema.SchemaEntry
This function will check whether a new schema is compatible with this one according to the passed in {@param expectedCompatibilityType}.
isNewSegment() - Method in class com.linkedin.venice.kafka.validation.Segment
 
isNoDaVinciStatusReport() - Method in class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
 
isNodeRemovable(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
No ACL check; any user is allowed to check whether a node is removable.
isNodeRemovable(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
isNodeRemovable(String, List<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
isNoSslHandshake(Throwable) - Static method in class com.linkedin.alpini.netty4.ssl.SslInitializer
 
isNotEmpty(Collection<?>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
isNullableUnionPair(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
 
isNullOrEmpty(String) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
isOfflinePushMonitorDaVinciPushStatusEnabled() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
isOfflinePushMonitorDaVinciPushStatusEnabled() - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
 
isOfflinePushMonitorDaVinciPushStatusEnabled() - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
ISOLATED - com.linkedin.davinci.ingestion.main.MainPartitionIngestionStatus
 
ISOLATED - com.linkedin.venice.meta.IngestionMode
Isolated ingestion is enabled.
ISOLATED_INGESTION_CONFIG_FILENAME - Static variable in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
ISOLATED_INGESTION_KAFKA_CLUSTER_MAP_FILENAME - Static variable in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
isolatedClients - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
isolatedIngestion() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
IsolatedIngestionBackend - Class in com.linkedin.davinci.ingestion
This class is the implementation of ingestion backend designed for ingestion isolation.
IsolatedIngestionBackend(VeniceConfigLoader, ReadOnlyStoreRepository, MetricsRepository, StorageMetadataService, KafkaStoreIngestionService, StorageService) - Constructor for class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
IsolatedIngestionNotifier - Class in com.linkedin.davinci.ingestion.isolated
 
IsolatedIngestionNotifier(IsolatedIngestionServer) - Constructor for class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
IsolatedIngestionProcessHeartbeatStats - Class in com.linkedin.davinci.stats
 
IsolatedIngestionProcessHeartbeatStats(MetricsRepository) - Constructor for class com.linkedin.davinci.stats.IsolatedIngestionProcessHeartbeatStats
 
IsolatedIngestionProcessStats - Class in com.linkedin.davinci.stats
IsolatedIngestionProcessStats is a metrics collecting class that aims to collect metrics from isolated ingestion process.
IsolatedIngestionProcessStats(MetricsRepository) - Constructor for class com.linkedin.davinci.stats.IsolatedIngestionProcessStats
 
IsolatedIngestionRequestClient - Class in com.linkedin.davinci.ingestion.isolated
This class sends requests to monitor service in main process and retrieves responses.
IsolatedIngestionRequestClient(VeniceConfigLoader) - Constructor for class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionRequestClient
 
IsolatedIngestionServer - Class in com.linkedin.davinci.ingestion.isolated
This class is the server service of the isolated ingestion.
IsolatedIngestionServer(String) - Constructor for class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
isolatedIngestionServerAclEnabled(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
IsolatedIngestionServerAclHandler - Class in com.linkedin.davinci.ingestion.isolated
 
IsolatedIngestionServerAclHandler(IdentityParser, String) - Constructor for class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerAclHandler
 
IsolatedIngestionServerChannelInitializer - Class in com.linkedin.davinci.ingestion.isolated
 
IsolatedIngestionServerChannelInitializer(IsolatedIngestionServer) - Constructor for class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerChannelInitializer
 
IsolatedIngestionServerHandler - Class in com.linkedin.davinci.ingestion.isolated
This is the handler class for IsolatedIngestionServer.
IsolatedIngestionServerHandler(IsolatedIngestionServer) - Constructor for class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerHandler
 
isolatedIngestionServerSslEnabled(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
IsolatedIngestionUtils - Class in com.linkedin.davinci.ingestion.utils
This class contains methods used for communication between ingestion client and server.
IsolatedIngestionUtils() - Constructor for class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
isOptimizeDatabaseForBackupVersionEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isParameterized() - Method in enum com.linkedin.venice.Arg
 
isParent() - Method in interface com.linkedin.venice.controller.Admin
Check whether the controller works as a parent controller
isParent() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isParent() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isParent() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isParent() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isParentExternalSupersetSchemaGenerationEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isParentReadInProgress() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
 
isParentSystemStoreRepairServiceEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isPartialUpdateOp(GenericRecord) - Static method in enum com.linkedin.venice.schema.writecompute.WriteComputeOperation
 
isParticipantMessageStoreEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isParticipantMessageStoreEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isParticipantStore(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
isPartitionConsuming(String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
isPartitionConsuming(String, int) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Check whether the specified partition is still being consumed
isPartitionConsumingOrHasPendingIngestionAction(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
To check whether the given partition is still consuming message from Kafka
isPartitionCountRoundUpEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isPartitionPausedIngestion(int) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
isPartitionReadyToServe(int) - Method in class com.linkedin.davinci.VersionBackend
 
isPartitionReadyToServe(VersionBackend, int) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
Check if user partition is ready to serve traffic.
isPartitionSubscribed(int) - Method in class com.linkedin.davinci.VersionBackend
 
isPartitionSubscribed(VersionBackend, int) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
isPermitHttp2() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
isPerNodeClientAllocationEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isPoolClosed() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
isPoolClosed() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
isPositive - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
isPresent() - Method in interface com.linkedin.venice.utils.lazy.Lazy
 
isPresent() - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
isPresent() - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
isProducingVersionTopicHealthy() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This function is checking the following conditions: 1.
isProhibitedCharacter(int) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Check if the character is prohibited in a HTTP header value.
isProjectionFieldValidationEnabled() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
isProjectionFieldValidationEnabled() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
isProjectionFieldValidationEnabled() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
isProjectionFieldValidationEnabled() - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
 
isProjectionFieldValidationEnabled() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isProjectionFieldValidationEnabled() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
isProjectionFieldValidationEnabled() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
isProjectionFieldValidationEnabled() - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
isPushIdRePush(String) - Static method in interface com.linkedin.venice.meta.Version
 
isPutReuseByteBufferEnabled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isPutValueChanged() - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaMessage
 
isQuotableParam(String) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
From RFC1341, a quoted value may contain any character except control characters or '"'.
isQuotaEnforcementEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isReadableDir(File) - Static method in class com.linkedin.venice.utils.Utils
Check if a directory exists and is readable
isReadableDir(String) - Static method in class com.linkedin.venice.utils.Utils
Check if a directory exists and is readable
isReadableFile(File) - Static method in class com.linkedin.venice.utils.Utils
Check if a file exists and is readable
isReadableFile(String) - Static method in class com.linkedin.venice.utils.Utils
Check if a file exists and is readable
isReadAsyncIOEanbled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isReadComputationEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isReadComputationEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isReadComputationEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isReadComputationEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isReadComputationEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isReadComputationEnabled(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
isReadComputationEnabled(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
isReadComputationEnabled(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
isReadComputationEnabled(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
Only return zk shared system store related info, otherwise VeniceException will be thrown.
isReadComputationEnabled(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Whether computation is enabled for the specified store.
isReadMetricsEnabled() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
isReadOnly() - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
isReadOnly() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
isReadOnly() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
isReadOnlyForBatchOnlyStoreEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isReadThrottlingEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isReady() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
isReady() - Method in class com.linkedin.venice.controllerapi.ReadyForDataRecoveryResponse
 
isReady() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
isReady() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
isReadyToServe() - Method in class com.linkedin.venice.routerapi.ReplicaState
 
isReadyToServe() - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
 
isReadyToServe(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This function checks various conditions to verify if a store is ready to serve.
isReadyToServeAnnouncedWithRTLag() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
used for metric purposes
isReadyToServeAnnouncedWithRTLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
isReadyToServeAnnouncedWithRTLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isReadyToStartBufferReplay(boolean) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
Checks whether at least one replica of each partition has returned ExecutionStatus.END_OF_PUSH_RECEIVED This is intended for OfflinePushStatus instances which belong to Hybrid Stores, though there should be no negative side-effects if called on an instance tied to a non-hybrid store, as the logic should consistently return false in that case.
isRealTime() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
isRealTimeBufferReplayStarted(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
isRealTimeBufferReplayStarted(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
isRealTimeBufferReplayStarted(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isRealTimeTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
isRecordLevelMetricWhenBootstrappingCurrentVersionEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isRecordTransformerEnabled() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
isRedundant(int, boolean) - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
isRedundantException(String) - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
isRedundantException(String, boolean) - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
isRedundantException(String, String) - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
isRedundantException(String, Throwable) - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
isRegistered - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Whether the segment is registered.
isRegistered() - Method in class com.linkedin.venice.kafka.validation.Segment
 
isRegularVersionETLEnabled() - Method in interface com.linkedin.venice.meta.ETLStoreConfig
 
isRegularVersionETLEnabled() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
isRemoteComputationOnly() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isRemovable() - Method in class com.linkedin.venice.controller.NodeRemovableResult
 
isRemovable() - Method in class com.linkedin.venice.controllerapi.NodeStatusResponse
 
isReplicaDisabled(String, int) - Method in interface com.linkedin.venice.pushmonitor.DisableReplicaCallback
 
isRepush - Variable in class com.linkedin.venice.kafka.protocol.VersionSwap
Flag to indicate this version swap is triggered by repush or not.
isReqRedirectionAllowedForQuery() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
isRequestOriginallyStreaming() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
 
isRequestRetriable(P, R, HRS) - Method in interface com.linkedin.alpini.router.api.RequestRetriableChecker
 
isRequestRetriable(P, R, HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
isRequestRetriable(P, R, HTTP_RESPONSE_STATUS) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
isRequestRetriable(P, R, HttpResponseStatus) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
isRequireClientCertOnLocalHost() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
isRequireClientCertOnLocalHost() - Method in class com.linkedin.venice.security.SSLConfig
 
isRequireHTTP2() - Method in class com.linkedin.venice.client.store.transport.HttpsTransportClient
 
isResolveBeforeSSL() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isResourceStillAlive(String) - Method in interface com.linkedin.venice.controller.Admin
Check whether the specified resource is fully removed or not.
isResourceStillAlive(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Test if a given helix resource is still alive (existent in ZK).
isResourceStillAlive(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
isResourceSubscribed(String, int) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
isRestoreDataPartitions() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
isRestoreMetadataPartition() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
isRestServiceEpollEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isRetentionBelowTruncatedThreshold(long, long) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
isRetryAllowed() - Method in class com.linkedin.venice.fastclient.meta.RetryManager
 
isRetryOnAllErrorsEnabled() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isRetryOnRouterErrorEnabled() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isRetryRequest() - Method in class com.linkedin.venice.listener.request.RouterRequest
 
isRetryRequest() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
ISRETRYREQUEST_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
isRetryRequestTooLate() - Method in class com.linkedin.venice.router.api.path.VenicePath
This function will check whether the retry request already passed the retry delay threshold.
isReusedChannel(Http2StreamChannel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Checks if a stream channel is a previously reused channel.
isRmdChunkingEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isRmdChunkingEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isRmdChunkingEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.meta.VersionImpl
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isRmdChunkingEnabled() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
isRocksDBPlainTableFormatEnabled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
DO NOT ENABLE! This is still experimental.
isRocksDBSetCacheIndexAndFilterBlocks() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isRocksDBStatisticsEnabled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isRocksDbStorageEngineConfigCheckEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isRocksDBStoreIndexInFile() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isRouterHeartBeatEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isRunning - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isRunning() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
A function to allow the service to get the current status of the task.
isRunning() - Method in class com.linkedin.venice.service.AbstractVeniceService
 
isSchemaAutoRegisterFromPushJobEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isSchemaAutoRegisterFromPushJobEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isSchemaIdValid() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
 
isSchemaPresenceCheckEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isSegmentControlMsg(ControlMessageType) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isServerAllowlistEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isServerCalculateQuotaUsageBasedOnPartitionsAssignmentEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isServerInAllowList(String, String, String, int, boolean) - Static method in class com.linkedin.venice.server.VeniceServer
 
isServerIngestionCheckpointDuringGracefulShutdownEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isServiceUnavailable(HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
isServiceUnavailable(HttpResponseStatus) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
isSessionIdValid() - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel.LeaderSessionIdChecker
 
isShellCmdExecuted() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
isShutdown() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
Returns true if this resource has been shut down.
isShutdown() - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
Returns true if this resource has been shut down.
isShutdown() - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
isShutdown() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Returns true if this resource has been shut down.
isShutdown() - Method in interface com.linkedin.alpini.base.registry.ShutdownableResource
Returns true if this resource has been shut down.
isShutdown() - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
 
isShutdown() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
isShutdown() - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
isShutdown() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
isShutdown() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
Returns true if this resource has been shut down.
isShutdown() - Method in class com.linkedin.venice.grpc.VeniceGrpcServer
 
isShuttingDown() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
isShuttingDown() - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
isShuttingDown() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
isShuttingDown() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
isSingleDecode() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
 
isSingleGetRouterCacheEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isSmartLongTailRetryEnabled() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
isSmartLongTailRetryEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isSourceETL - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isSourceKafka - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isSpecificClient() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isSpeculativeQueryEnabled() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
isSsl(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
isSslEnabled() - Method in interface com.linkedin.alpini.base.ssl.SslFactory
 
isSslEnabled() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
isSslEnabled() - Method in class com.linkedin.venice.controller.server.AbstractRoute
 
isSslEnabled() - Method in class com.linkedin.venice.security.DefaultSSLFactory
 
isSslEnabled() - Method in interface com.linkedin.venice.security.SSLFactory
 
isSSLEnabledForPush(String, String) - Method in interface com.linkedin.venice.controller.Admin
Return whether ssl is enabled for the given store for push.
isSSLEnabledForPush(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isSSLEnabledForPush(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isSslNeedsClientCert() - Method in class com.linkedin.venice.SSLConfig
 
isSslRequireClientCerts() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
isSslRequireClientCerts() - Method in class com.linkedin.venice.security.DefaultSSLFactory
 
isSslToKafka() - Method in interface com.linkedin.venice.controller.Admin
 
isSslToKafka() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
isSslToKafka() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isSslToKafka() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Test if ssl is enabled to Kafka.
isSslToKafka() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isSslToKafka() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isSslToStorageNodes() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isStaleChannel() - Method in class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
 
isStarted() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isStarted() - Method in class com.linkedin.venice.d2.D2Server
 
isStarted() - Method in class com.linkedin.venice.d2.D2ServerManager
 
isStarted() - Method in class com.linkedin.venice.kafka.validation.Segment
 
isStarted() - Method in class com.linkedin.venice.server.VeniceServer
 
isStartMessage(I) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Returns true if and only if the specified message is a start message.
isStartMessage(HttpObject) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
isStartMessage(HttpObject) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
isStatCallBackExecuted() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
isStatefulRouterHealthCheckEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isStorageNodeNewerOrEqualTo(String, String, StorageNodeStatus) - Method in interface com.linkedin.venice.controller.Admin
Compare the current storage node status and the given storage node status to check is the current one is "Newer" or "Equal" to the given one.
isStorageNodeNewerOrEqualTo(String, String, StorageNodeStatus) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isStorageNodeNewerOrEqualTo(String, String, StorageNodeStatus) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
isStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isStorageNodeReadQuotaEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isStoreGraveyardCleanupEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isStoreIncrementalPushEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isStoreMetadataSystemStoreEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isStoreMetadataSystemStoreEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isStoreMetadataSystemStoreEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isStoreMetadataSystemStoreEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isStoreMetadataSystemStoreEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isStoreMetaSystemStoreEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isStoreMetaSystemStoreEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isStoreMetaSystemStoreEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isStoreMetaSystemStoreEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isStoreMetaSystemStoreEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isStoreMigrationAllowed() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
isStoreMigrationAllowed() - Method in class com.linkedin.venice.controllerapi.StoreMigrationResponse
 
isStoreMigrationAllowed() - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
isStoreMigrationAllowed(Admin) - Method in class com.linkedin.venice.controller.server.ClusterRoutes
No ACL check; any user is allowed to check whether store migration is allowed for a specific cluster.
isStoreMigrationAllowed(String) - Method in interface com.linkedin.venice.controller.Admin
 
isStoreMigrationAllowed(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Test if the store migration is allowed for a cluster.
isStoreMigrationAllowed(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isStoreNameValid(String) - Static method in class com.linkedin.venice.router.api.VenicePathParser
 
isStorePersistenceTypeKnown() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
For some store, the persistence type may not be known when constructing VeniceStoreVersionConfig, such as in `VeniceStateModelFactory#createNewStateModel`, when Helix wants to create a new state model for some store, it doesn't know the persistence type since it is possible that this store is an existing store, so the persistence type is decided by the on-disk type, and it is a new store, it will be decided by storage node config.
isStoreVersionLingering(Store, Version, Time, Admin, Optional<X509Certificate>, IdentityParser) - Method in class com.linkedin.venice.controller.lingeringjob.DefaultLingeringStoreVersionChecker
 
isStoreVersionLingering(Store, Version, Time, Admin, Optional<X509Certificate>, IdentityParser) - Method in class com.linkedin.venice.controller.lingeringjob.HeartbeatBasedLingeringStoreVersionChecker
 
isStoreVersionLingering(Store, Version, Time, Admin, Optional<X509Certificate>, IdentityParser) - Method in interface com.linkedin.venice.controller.lingeringjob.LingeringStoreVersionChecker
Check if a version has been lingering around
isStoreVersionReadyForDataRecovery(Admin) - Method in class com.linkedin.venice.controller.server.DataRecoveryRoutes
 
isStoreVersionReadyForDataRecovery(String, String, int, String, String, Optional<Integer>) - Method in interface com.linkedin.venice.controller.Admin
Check if the store version's previous states and resources are cleaned up and ready to start data recovery.
isStoreVersionReadyForDataRecovery(String, String, int, String, String, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
isStoreVersionReadyForDataRecovery(String, String, int, String, String, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isStoreVersionReadyForDataRecovery(String, String, String, int, Optional<Integer>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
isStoreWriteComputeEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isStoreWriterBufferAfterLeaderLogicEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isStoreZkShared() - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
 
isStreamingEnabled(HttpRequest) - Static method in class com.linkedin.venice.streaming.StreamingUtils
 
isStreamingEncoding(CharSequence) - Static method in class com.linkedin.alpini.netty4.compression.CompressionUtils
Test if the specified encoding names an encoding which may be streamed.
isStreamingRequest() - Method in class com.linkedin.venice.listener.request.RouterRequest
 
isStreamingRequest() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
ISSTREAMINGREQUEST_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
isStreamingResponse() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
ISSTREAMINGRESPONSE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
 
isStreamReprocessing() - Method in enum com.linkedin.venice.meta.Version.PushType
 
isStreamReprocessingTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
isStreamReprocessingTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
isStuckByMemoryConstraint() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isStuckConsumerRepairEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isSubscribed() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isSucceedInAllFabric() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
isSuccess() - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Returns true if and only if the I/O operation was completed successfully.
isSuccess() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
isSuccess() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Returns true if and only if the I/O operation was completed successfully.
isSuccess() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Returns true if and only if the I/O operation was completed successfully.
isSuccess() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
isSuccessfulException(Throwable) - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
isSuccessStatus(int) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
isSuccessStatus(HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
isSuccessStatus(HttpResponseStatus) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
isSupersetSchema(Schema, Schema) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
 
isSuperSetSchemaAutoGenerationForReadComputeEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isSupportedEncoding(CharSequence) - Static method in class com.linkedin.alpini.netty4.compression.CompressionUtils
Test if the supplied Accepts-Encoding string matches any specific supported encoding.
isSupportedSpecificEncoding(CharSequence) - Static method in class com.linkedin.alpini.netty4.compression.CompressionUtils
Test if the specified encoding names a specific supported encoding.
isSwitchingToNonHttp1Protocol(HttpResponse) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
Returns true if the server switched to a different protocol than HTTP/1.0 or HTTP/1.1, e.g.
isSystemSchemaInitializationAtStartTimeEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isSystemSchemaInitializationAtStartTimeEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isSystemSchemaReaderEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isSystemStore() - Method in class com.linkedin.venice.meta.AbstractStore
 
isSystemStore() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isSystemStore() - Method in interface com.linkedin.venice.meta.Store
 
isSystemStore(String) - Method in enum com.linkedin.venice.common.VeniceSystemStoreType
This function is used to check whether the passed store name belongs to the current system store type.
isSystemStore(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
isSystemStore(String) - Static method in interface com.linkedin.venice.meta.Store
 
isSystemStoreTypeEnabledInUserStore(Store, VeniceSystemStoreType) - Static method in class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
This method checks if a specific system store type is enabled in a given user store.
isTargetedRegionPushEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isTaskStatus() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isTempRMDSSTFile(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
isTempSSTFile(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
isTerminal() - Method in enum com.linkedin.venice.hadoop.jobs.ComputeJob.Status
 
isTerminal() - Method in enum com.linkedin.venice.kafka.validation.SegmentStatus
 
isTerminal() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isTerminal(int) - Static method in enum com.linkedin.venice.status.PushJobDetailsStatus
 
isTerminated() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
Returns true if the resource has completed shutting down.
isTerminated() - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
Returns true if the resource has completed shutting down.
isTerminated() - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
isTerminated() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Returns true if the resource has completed shutting down.
isTerminated() - Method in interface com.linkedin.alpini.base.registry.ShutdownableResource
Returns true if the resource has completed shutting down.
isTerminated() - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
 
isTerminated() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
isTerminated() - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
isTerminated() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
isTerminated() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
Returns true if the resource has completed shutting down.
isTerminated() - Method in class com.linkedin.venice.grpc.VeniceGrpcServer
 
isThrottlingEnabled() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
isThrottlingEnabled() - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
isThrottlingEnabled() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
 
isTimedOut() - Method in class com.linkedin.alpini.io.ExternalCommand
 
isTooLongFrameException(Throwable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
isTooLongFrameException(Throwable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
isTooLongFrameException(Throwable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
isTooManyActiveStreamsError(Throwable) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Checks if an exception is thrown because of too many active streams.
isTooManyActiveStreamsError(Throwable) - Static method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
Deprecated.
isTopicCompactionEnabled(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
isTopicPartitionInLeaderState(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
isTopicTruncated(PubSubTopic, long) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Check whether topic is absent or truncated
isTopicTruncated(String) - Method in interface com.linkedin.venice.controller.Admin
 
isTopicTruncated(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Check if a kafka topic is absent or truncated.
isTopicTruncated(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isTopicTruncatedBasedOnRetention(long) - Method in interface com.linkedin.venice.controller.Admin
 
isTopicTruncatedBasedOnRetention(long) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Test if retention is less than the configured DEPRECATED_TOPIC_MAX_RETENTION_MS value.
isTopicTruncatedBasedOnRetention(long) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isTopicTruncatedBasedOnRetention(String, long) - Method in interface com.linkedin.venice.controller.Admin
 
isTopicTruncatedBasedOnRetention(String, long) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Topic should also be considered to get cleaned up if: retention is less than the configured ConfigKeys.DEPRECATED_TOPIC_MAX_RETENTION_MS value.
isTopicTruncatedBasedOnRetention(String, long) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
isTotalStats() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
isTraceEnabled() - Method in class com.linkedin.alpini.log.FastLog
 
isTraceEnabled() - Method in class com.linkedin.alpini.log.FastLogContext
 
isTraceEnabled() - Method in class com.linkedin.alpini.log.FastLogger
 
isTraceEnabled() - Method in interface com.linkedin.alpini.log.FastLogMBean
 
isTraceEnabled(Marker) - Method in class com.linkedin.alpini.log.FastLogger
 
isTransientRecordBufferUsed() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
For Active-Active this buffer is always used.
isTransientRecordBufferUsed() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This is not a per record state.
isTrue(AttributeMap, AttributeKey<Boolean>) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
isUnexpectedError(long, boolean) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
isUnexpectedError(Http2Error) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
isUnexpectedError(Http2Error, boolean) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Returns true, if the enum is a known error or unknown error code.
isUnregisterMetricForDeletedStoreEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isUnregisterMetricForDeletedStoreEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isUnregisterMetricForDeletedStoreEnabled() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isUnresolvedUnionExceptionAvailable() - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
 
isUnsubscribeAfterBatchpushEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
isUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isUnusedSchemaDeletionEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isUnusedValueSchemaCleanupServiceEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isUpdateIgnored() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
 
isUpdateIgnored() - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
isUpperCase(byte) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
isUpperCase(char) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
isUseBlackHoleDeserializer() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isUseCustomMultiplexHandler() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
Deprecated.
isUsedByDaVinciClientOnly() - Method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
 
isUseFastAvro() - Method in class com.linkedin.venice.client.store.ClientConfig
 
isUseGroupFieldInHelixDomain() - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
isUseOpenSsl() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
isUseRefCount() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
isUserSystemStore() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isUserSystemStore(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
isUseSeparateRMDCacheEnabled() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
isUseVersionLevelHybridConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isUseVersionLevelHybridConfig() - Method in interface com.linkedin.venice.meta.Version
 
isUseVersionLevelHybridConfig() - Method in class com.linkedin.venice.meta.VersionImpl
 
isUseVersionLevelIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isUseVersionLevelIncrementalPushEnabled() - Method in interface com.linkedin.venice.meta.Version
 
isUseVersionLevelIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.VersionImpl
 
isUsingFastPool() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
isValid() - Method in class com.linkedin.venice.schema.GeneratedSchemaID
 
isValidateCertificates() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
 
isValidateHeaders() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
isValidateHeaders() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
isValidAvroSchema(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
 
isValidStoreName(String) - Static method in interface com.linkedin.venice.meta.Store
 
isVeniceClusterLeaderHAAS() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isVeniceControllerClusterCreated() - Method in interface com.linkedin.venice.controller.HelixAdminClient
Check if the Venice controller cluster is created and configured.
isVeniceControllerClusterCreated() - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
isVeniceStorageClusterCreated(String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Check if the given Venice storage cluster is created and configured.
isVeniceStorageClusterCreated(String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
isVeniceStorageClusterInControllerCluster(String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Check if the given Venice storage cluster's cluster resource is in the Venice controller cluster.
isVeniceStorageClusterInControllerCluster(String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
isVersionErrored(VersionStatus) - Static method in enum com.linkedin.venice.meta.VersionStatus
 
isVersionKilled(VersionStatus) - Static method in enum com.linkedin.venice.meta.VersionStatus
 
isVersionOnline() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
isVersionSwapDeferred() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
isVersionSwapDeferred() - Method in interface com.linkedin.venice.meta.Version
 
isVersionSwapDeferred() - Method in class com.linkedin.venice.meta.VersionImpl
 
isVersionTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
isVersionTopic(String) - Static method in interface com.linkedin.venice.meta.Version
Only return true if the input topic name is a version topic.
isVersionTopicOrStreamReprocessingTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
isVersionTopicOrStreamReprocessingTopic(String) - Static method in interface com.linkedin.venice.meta.Version
Return true if the input topic name is a version topic or stream-reprocessing topic.
isViable() - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
isViewTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
 
isViewTopic(String) - Static method in class com.linkedin.venice.views.VeniceView
 
isVisible(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
isVoid() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
isVoid() - Method in class io.netty.bootstrap.PendingConnectPromise
 
isVsonClient() - Method in class com.linkedin.venice.client.store.ClientConfig
Deprecated.
isVsonStore() - Method in class com.linkedin.venice.fastclient.ClientConfig
Deprecated.
isWaitingForReplicationLag() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
isWarnEnabled() - Method in class com.linkedin.alpini.log.FastLogger
 
isWarnEnabled(Marker) - Method in class com.linkedin.alpini.log.FastLogger
 
isWrapperFor(Class<?>) - Method in interface com.linkedin.alpini.base.pool.AsyncPool.LifeCycle
 
isWrapperFor(Class<?>) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleFilter
 
isWritable() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
isWritable(int) - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
isWriteComputationEnabled - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
isWriteComputationEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
isWriteComputationEnabled() - Method in interface com.linkedin.venice.meta.Store
 
isWriteComputationEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
 
isWriteComputationEnabled() - Method in class com.linkedin.venice.meta.SystemStore
 
isWriteComputationEnabled() - Method in class com.linkedin.venice.meta.ZKStore
 
isWriteOnlyConfig() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
isZkSharedDaVinciPushStatusSystemSchemaStoreAutoCreationEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isZkSharedDaVinciPushStatusSystemSchemaStoreAutoCreationEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isZkSharedMetaSystemSchemaStoreAutoCreationEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
isZkSharedMetaSystemSchemaStoreAutoCreationEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
isZstdDictCreationRequired - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
isZstdDictCreationRequired - Variable in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
isZstdDictCreationSuccess - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
iterateOnMapOfLists(Map<K, List<V>>) - Static method in class com.linkedin.venice.utils.Utils
 
iterator() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
iterator() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
iterator() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
 
iterator() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
iterator() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
iterator() - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
iterator() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
iterator() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
iterator() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
iterator() - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
iteratorCharSequence() - Method in interface com.linkedin.alpini.base.misc.Headers
 
iteratorCharSequence() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
iteratorCharSequence() - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
IteratorUtil - Class in com.linkedin.alpini.base.misc
Utility methods for Iterators.
IteratorUtils - Class in com.linkedin.venice.utils
 

J

JavaUtilGuidV4Generator - Class in com.linkedin.venice.guid
A Guid generator which internally uses UUID.randomUUID().
JavaUtilGuidV4Generator() - Constructor for class com.linkedin.venice.guid.JavaUtilGuidV4Generator
Required in order to construct via reflection.
JDBCUtils - Enum in com.linkedin.alpini.base.misc
Utility methods for JDBC.
JDK_HOME_DIR - Static variable in class com.linkedin.alpini.io.ExternalCommand
 
JenkinsHashFunction - Class in com.linkedin.alpini.base.hash
Hash algorithm by Bob Jenkins, 1996.
JenkinsHashFunction() - Constructor for class com.linkedin.alpini.base.hash.JenkinsHashFunction
 
JOB - com.linkedin.venice.controllerapi.ControllerRoute
 
JOB_EXEC_ID - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
The execution ID of the execution if this job is a part of a multi-step flow.
JOB_EXEC_URL - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
This will define the execution servers url for easy access to the job execution during debugging.
JOB_SERVER_NAME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
The short name of the server where the job runs
JOB_STATUS - com.linkedin.venice.Command
 
JOB_STATUS_IN_UNKNOWN_STATE_TIMEOUT_MS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
JOB_STATUS_POLLING_COMPLETED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
JobClientWrapper - Interface in com.linkedin.venice.hadoop
 
jobDurationInMs - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
jobExecutionId - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
jobId - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
JobRoutes - Class in com.linkedin.venice.controller.server
 
JobRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.JobRoutes
 
jobServerName - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
jobStartTimeMs - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
jobStatus(Admin) - Method in class com.linkedin.venice.controller.server.JobRoutes
 
jobStatusInUnknownStateTimeoutMs - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
JobStatusQueryResponse - Class in com.linkedin.venice.controllerapi
Response for querying job status.
JobStatusQueryResponse() - Constructor for class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
JobUtils - Class in com.linkedin.venice.hadoop.mapreduce.common
 
join() - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
join(A...) - Method in class com.linkedin.alpini.base.misc.Joiner
 
join(A, A, A[]) - Method in class com.linkedin.alpini.base.misc.Joiner
 
join(Iterable<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
join(Iterator<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
Joiner - Class in com.linkedin.alpini.base.misc
A replacement to the use of the Google collections class of the same name,
Joiner(String) - Constructor for class com.linkedin.alpini.base.misc.Joiner
 
JSON - Static variable in class com.linkedin.venice.HttpConstants
 

K

KAFKA_ADMIN_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
The class name to use for the PubSubAdminAdapter.
KAFKA_ADMIN_GET_TOPIC_CONFIG_MAX_RETRY_TIME_SEC - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_AUTO_OFFSET_RESET_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_AUTO_OFFSET_RESET_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_BOOTSTRAP_SERVERS - com.linkedin.venice.Arg
 
KAFKA_BOOTSTRAP_SERVERS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_BOOTSTRAP_SERVERS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_BUFFER_MEMORY - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_CLIENT_ID - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_CLIENT_ID_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_CLIENT_ID_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_CLIENT_METRICS_DEFAULT - com.linkedin.venice.stats.StatsErrorCode
Default value for kafka client metrics.
KAFKA_CLUSTER_MAP_FILE - Static variable in class com.linkedin.davinci.config.VeniceConfigLoader
 
KAFKA_CLUSTER_MAP_KEY_NAME - Static variable in class com.linkedin.venice.ConfigKeys
Defines the key names in venice.server.kafkaClustersMap
KAFKA_CLUSTER_MAP_KEY_OTHER_URLS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_CLUSTER_MAP_KEY_URL - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_CLUSTER_MAP_SECURITY_PROTOCOL - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_CONFIG_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_CONFIG_PREFIX - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_CONSUMER_CONFIG_FILE - com.linkedin.venice.Arg
 
KAFKA_EMPTY_POLL_SLEEP_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_ENABLE_AUTO_COMMIT_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_ENABLE_AUTO_COMMIT_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_FETCH_MAX_BYTES_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_MAX_BYTES_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_FETCH_MAX_SIZE_PER_SEC - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_MAX_WAIT_MS_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_MAX_WAIT_MS_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_FETCH_MAX_WAIT_TIME_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_MIN_BYTES_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_MIN_BYTES_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_FETCH_MIN_SIZE_PER_SEC - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_PARTITION_MAX_SIZE_PER_SEC - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_QUOTA_BYTES_PER_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_QUOTA_RECORDS_PER_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
How many records that one server could consume from Kafka at most in one second.
KAFKA_FETCH_QUOTA_TIME_WINDOW_MS - Static variable in class com.linkedin.venice.ConfigKeys
The time window used by the consumption throttler.
KAFKA_FETCH_QUOTA_UNORDERED_BYTES_PER_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_FETCH_QUOTA_UNORDERED_RECORDS_PER_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_GROUP_ID_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_GROUP_ID_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_INGESTION_SERVICE - com.linkedin.venice.ingestion.protocol.enums.IngestionComponentType
 
KAFKA_INPUT_BROKER_URL - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_INPUT_COMBINER_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_INPUT_COMPRESSION_BUILD_NEW_DICT_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_INPUT_FABRIC - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_INPUT_MAX_RECORDS_PER_MAPPER - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_INPUT_SOURCE_COMPRESSION_STRATEGY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_INPUT_SOURCE_TOPIC_CHUNKING_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_INPUT_TOPIC - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
TODO: consider to automatically discover the source topic for the specified store.
KAFKA_KEY_SERIALIZER - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_LINGER_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_LINGER_MS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_LOG_COMPACTION_FOR_HYBRID_STORES - Static variable in class com.linkedin.venice.ConfigKeys
Whether to turn on Kafka's log compaction for the store-version topics of hybrid (and real-time only) stores.
KAFKA_MAX_PARTITION_FETCH_BYTES_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_MAX_PARTITION_FETCH_BYTES_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_MAX_POLL_RECORDS_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_MAX_POLL_RECORDS_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
KAFKA_MESSAGE_ENVELOPE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used for the Kafka topics, including the main data topics as well as the admin topic.
KAFKA_MIN_IN_SYNC_REPLICAS - Static variable in class com.linkedin.venice.ConfigKeys
The minimum number of in sync replicas to set for store version topics.
KAFKA_MIN_IN_SYNC_REPLICAS_ADMIN_TOPICS - Static variable in class com.linkedin.venice.ConfigKeys
The minimum number of in sync replicas to set for admin topics.
KAFKA_MIN_IN_SYNC_REPLICAS_RT_TOPICS - Static variable in class com.linkedin.venice.ConfigKeys
The minimum number of in sync replicas to set for real-time buffer topics.
KAFKA_MIN_LOG_COMPACTION_LAG_MS - Static variable in class com.linkedin.venice.ConfigKeys
For log compaction enabled topics, this config will define the minimum time a message will remain uncompacted in the log.
KAFKA_OPERATION_TIMEOUT - com.linkedin.venice.Arg
 
KAFKA_OVER_SSL - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_OVER_SSL - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_PRODUCER_DELIVERY_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_PRODUCER_DELIVERY_TIMEOUT_MS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_PRODUCER_METRICS - Static variable in class com.linkedin.venice.ConfigKeys
a comma seperated list of kafka producer metrics that will be reported.
KAFKA_PRODUCER_REQUEST_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_PRODUCER_REQUEST_TIMEOUT_MS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_PRODUCER_RETRIES_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_PRODUCER_RETRIES_CONFIG - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_READ_CYCLE_DELAY_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_READ_ONLY_ADMIN_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
Fully-qualified class name to use for Kafka read-only admin operations.
KAFKA_REPLICATION_FACTOR - Static variable in class com.linkedin.venice.ConfigKeys
The replication factor to set for store-version topics.
KAFKA_REPLICATION_FACTOR_RT_TOPICS - Static variable in class com.linkedin.venice.ConfigKeys
The replication factor to set for real-time buffer topics.
KAFKA_SECURITY_PROTOCOL - Static variable in class com.linkedin.venice.ConfigKeys
 
KAFKA_SECURITY_PROTOCOL - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_SOURCE_KEY_SCHEMA_STRING_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KAFKA_TOPIC_LOG_COMPACTION_ENABLED - com.linkedin.venice.Arg
 
KAFKA_TOPIC_LOG_COMPACTION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
KAFKA_TOPIC_MIN_IN_SYNC_REPLICA - com.linkedin.venice.Arg
 
KAFKA_TOPIC_MIN_IN_SYNC_REPLICA - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
KAFKA_TOPIC_NAME - com.linkedin.venice.Arg
 
KAFKA_TOPIC_PARTITION - com.linkedin.venice.Arg
 
KAFKA_TOPIC_RETENTION_IN_MS - com.linkedin.venice.Arg
 
KAFKA_TOPIC_RETENTION_IN_MS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
KAFKA_VALUE_SERIALIZER - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
KAFKA_WRITE_ONLY_ADMIN_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
Fully-qualified class name to use for Kafka write-only admin operations.
KafkaClusterBasedRecordThrottler - Class in com.linkedin.davinci.kafka.consumer
This class is used to throttle records consumed per Kafka cluster
KafkaClusterBasedRecordThrottler(Map<String, EventThrottler>) - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaClusterBasedRecordThrottler
 
kafkaClusterIdToUrlMap - Variable in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
kafkaClusterUrlResolver - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
KafkaConsumerException - Exception in com.linkedin.venice.exceptions
Custom Exception for Venice Kafka Consumer Related Issues.
KafkaConsumerException(String) - Constructor for exception com.linkedin.venice.exceptions.KafkaConsumerException
 
KafkaConsumerException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.KafkaConsumerException
 
KafkaConsumerService - Class in com.linkedin.davinci.kafka.consumer
KafkaConsumerService is used to manage a pool of consumption-related resources connected to a specific Kafka cluster.
KafkaConsumerService(PubSubConsumerAdapterFactory, Properties, long, int, EventThrottler, EventThrottler, KafkaClusterBasedRecordThrottler, MetricsRepository, String, long, TopicExistenceChecker, boolean, PubSubMessageDeserializer, Time, AggKafkaConsumerServiceStats, boolean, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
KafkaConsumerService.ConsumerAssignmentStrategy - Enum in com.linkedin.davinci.kafka.consumer
This consumer assignment strategy specify how consumers from consumer pool are allocated.
KafkaConsumerServiceDelegator - Class in com.linkedin.davinci.kafka.consumer
This delegator impl is used to distribute different partition requests into different consumer service.
KafkaConsumerServiceDelegator(VeniceServerConfig, BiFunction<Integer, String, KafkaConsumerService>, Function<String, Boolean>) - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
KafkaConsumerServiceStats - Class in com.linkedin.davinci.stats
This class provides the stats for Kafka consumer service per region or per store.
KafkaConsumerServiceStats(MetricsRepository, String, LongSupplier, KafkaConsumerServiceStats, Time) - Constructor for class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
KafkaDataIntegrityValidator - Class in com.linkedin.davinci.validation
This class is a library that can validate the Kafka message during consumption, which can be used in Venice-Server/Da-Vinci and ETL.
KafkaDataIntegrityValidator(String) - Constructor for class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
 
KafkaDataIntegrityValidator(String, long) - Constructor for class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
This constructor is used by a proprietary ETL project.
KafkaDataIntegrityValidator(String, long, long) - Constructor for class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
 
kafkaInputBrokerUrl - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
kafkaInputBuildNewDictEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
kafkaInputCombinerEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
KafkaInputDataInfoProvider - Class in com.linkedin.venice.hadoop
 
KafkaInputDataInfoProvider() - Constructor for class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
 
KafkaInputDictTrainer - Class in com.linkedin.venice.hadoop.input.kafka
Zstd dict trainer for Kafka Repush.
KafkaInputDictTrainer(KafkaInputDictTrainer.Param) - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer
 
KafkaInputDictTrainer(KafkaInputFormat, Optional<ZstdDictTrainer>, KafkaInputDictTrainer.Param, KafkaInputDictTrainer.CompressorBuilder) - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer
 
KafkaInputDictTrainer.Param - Class in com.linkedin.venice.hadoop.input.kafka
 
KafkaInputDictTrainer.ParamBuilder - Class in com.linkedin.venice.hadoop.input.kafka
 
KafkaInputFormat - Class in com.linkedin.venice.hadoop.input.kafka
We borrowed some idea from the open-sourced attic-crunch lib: https://github.com/apache/attic-crunch/blob/master/crunch-kafka/src/main/java/org/apache/crunch/kafka/record/KafkaInputFormat.java This InputFormat implementation is used to read data off a Kafka topic.
KafkaInputFormat() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
 
KafkaInputFormatCombiner - Class in com.linkedin.venice.hadoop.input.kafka
This class is a Combiner, which is a functionality of the MR framework where we can plug a Reducer implementation to be executed within the Mapper task, on its output.
KafkaInputFormatCombiner() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormatCombiner
 
KafkaInputKeyComparator - Class in com.linkedin.venice.hadoop.input.kafka
This class is used to support secondary sorting for KafkaInput Repush.
KafkaInputKeyComparator() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
 
KafkaInputMapperKey - Class in com.linkedin.venice.hadoop.input.kafka.avro
The protocol between Mapper and Reducer with KafkaInputFormat for key field
KafkaInputMapperKey() - Constructor for class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
Default constructor.
KafkaInputMapperKey(ByteBuffer, Long) - Constructor for class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
All-args constructor.
KafkaInputMapperValue - Class in com.linkedin.venice.hadoop.input.kafka.avro
The data protocol between Mapper and Reducer for KafkaInputFormat
KafkaInputMapperValue() - Constructor for class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Default constructor.
KafkaInputMapperValue(MapperValueType, ByteBuffer, Long, Integer, ByteBuffer, Integer, ByteBuffer) - Constructor for class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
All-args constructor.
KafkaInputMRPartitioner - Class in com.linkedin.venice.hadoop.input.kafka
This class is used for KafkaInput Repush, and it only considers the key part of the composed key (ignoring the offset).
KafkaInputMRPartitioner() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputMRPartitioner
 
KafkaInputRecordReader - Class in com.linkedin.venice.hadoop.input.kafka
We borrowed some idea from the open-sourced attic-crunch lib: https://github.com/apache/attic-crunch/blob/master/crunch-kafka/src/main/java/org/apache/crunch/kafka/record/KafkaRecordReader.java This class is used to read data off a Kafka topic partition.
KafkaInputRecordReader(InputSplit, JobConf, DataWriterTaskTracker) - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
KafkaInputRecordReader(InputSplit, JobConf, DataWriterTaskTracker, PubSubConsumerAdapter) - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
KafkaInputSplit - Class in com.linkedin.venice.hadoop.input.kafka
We borrowed some idea from the open-sourced attic-crunch lib: https://github.com/apache/attic-crunch/blob/master/crunch-kafka/src/main/java/org/apache/crunch/kafka/record/KafkaInputSplit.java InputSplit that represent retrieving data from a single TopicPartition between the specified start and end offsets.
KafkaInputSplit() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
Nullary Constructor for creating the instance inside the Mapper instance.
KafkaInputSplit(String, int, long, long) - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
Constructs an input split for the provided {@param topic} and {@param partition} restricting data to be between the {@param startingOffset} and {@param endingOffset}
kafkaInputTopic - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
KafkaInputUtils - Class in com.linkedin.venice.hadoop.input.kafka
 
KafkaInputUtils() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputUtils
 
KafkaInputValueGroupingComparator - Class in com.linkedin.venice.hadoop.input.kafka
This class together with KafkaInputKeyComparator supports secondary sorting of KafkaInput Repush.
KafkaInputValueGroupingComparator() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputValueGroupingComparator
 
KafkaKey - Class in com.linkedin.venice.message
Class which stores the components of a Kafka Key, and is the format specified in the KafkaKeySerializer.
KafkaKey(byte, byte[]) - Constructor for class com.linkedin.venice.message.KafkaKey
 
KafkaKey(MessageType, byte[]) - Constructor for class com.linkedin.venice.message.KafkaKey
 
KafkaKeySerializer - Class in com.linkedin.venice.serialization
VeniceKafkaSerializer to encode/decode KafkaKey for Venice customized kafka message Used by Kafka to convert to/from byte arrays.
KafkaKeySerializer() - Constructor for class com.linkedin.venice.serialization.KafkaKeySerializer
 
KafkaMessageEnvelope - Class in com.linkedin.venice.kafka.protocol
 
KafkaMessageEnvelope() - Constructor for class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Default constructor.
KafkaMessageEnvelope(Integer, ProducerMetadata, Object, LeaderMetadata) - Constructor for class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
All-args constructor.
kafkaProps - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
kafkaSourceRegion - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
KafkaSSLUtils - Class in com.linkedin.venice.utils
 
KafkaSSLUtils() - Constructor for class com.linkedin.venice.utils.KafkaSSLUtils
 
KafkaStoreIngestionService - Class in com.linkedin.davinci.kafka.consumer
Assumes: One to One mapping between a Venice Store and Kafka Topic.
KafkaStoreIngestionService(StorageEngineRepository, VeniceConfigLoader, StorageMetadataService, ClusterInfoProvider, ReadOnlyStoreRepository, ReadOnlySchemaRepository, ReadOnlyLiveClusterConfigRepository, MetricsRepository, Optional<SchemaReader>, Optional<ClientConfig>, InternalAvroSpecificSerializer<PartitionState>, Optional<HelixReadOnlyZKSharedSchemaRepository>, ICProvider, boolean, StorageEngineBackedCompressorFactory, Optional<ObjectCacheBackend>, Function<Integer, DaVinciRecordTransformer>, boolean, RemoteIngestionRepairService, PubSubClientsFactory, Optional<SSLFactory>, HeartbeatMonitoringService) - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
kafkaTopic - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
KafkaTopicDumper - Class in com.linkedin.venice
This class contains logic to dump Venice Kafka topics.
KafkaTopicDumper(ControllerClient, PubSubConsumerAdapter, String, int, long, int, String, int, boolean, boolean, boolean) - Constructor for class com.linkedin.venice.KafkaTopicDumper
 
kafkaTopicName() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
kafkaTopicName() - Method in interface com.linkedin.venice.meta.Version
Kafka topic name is composed by store name and version.
kafkaTopicName() - Method in class com.linkedin.venice.meta.VersionImpl
Kafka topic name is composed by store name and version.
kafkaUrl - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
kafkaUrl - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
kafkaUrlForLogger - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
kafkaUrlToThrottledRecords - Variable in class com.linkedin.davinci.kafka.consumer.KafkaClusterBasedRecordThrottler
 
KafkaValueSerializer - Class in com.linkedin.venice.serialization.avro
Serializer for the Avro-based kafka protocol defined in: KafkaMessageEnvelope This class needs to be defined explicitly, rather than just instantiating a InternalAvroSpecificSerializer because it is used as a config passed to the Kafka producer.
KafkaValueSerializer() - Constructor for class com.linkedin.venice.serialization.avro.KafkaValueSerializer
 
KafkaValueSerializer(BiConsumer<Integer, Schema>) - Constructor for class com.linkedin.venice.serialization.avro.KafkaValueSerializer
 
kafkaVersionTopic - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Topics used for this topic consumption TODO: Using a PubSubVersionTopic and PubSubRealTimeTopic extending PubSubTopic for type safety.
KEEP_MIN_VERSIONS - com.linkedin.venice.meta.BackupStrategy
Keep numVersionsToPreserve number of backup version.
keepPollingWhenEmpty - Variable in class com.linkedin.venice.unit.kafka.consumer.poll.AbstractPollStrategy
 
key - Variable in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
The key which corresponds to this record which was just updated.
key - Variable in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Raw bytes of the key
key - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
The raw key bytes excluding any chunking suffix
key - Variable in class com.linkedin.venice.unit.kafka.InMemoryKafkaMessage
 
key - Variable in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter.SendMessageParameters
 
key() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeader
 
KEY - com.linkedin.venice.Arg
 
KEY_COLUMN_NAME - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
KEY_FIELD_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KEY_ID_FOR_STREAMING_FOOTER - Static variable in class com.linkedin.venice.streaming.StreamingConstants
Here will use a special key id to differentiate the footer record from the regular record.
KEY_INPUT_FILE_DATA_SIZE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KEY_NOT_FOUND - Static variable in class com.linkedin.venice.grpc.GrpcErrorCodes
 
KEY_SCHEMA - com.linkedin.venice.Arg
 
KEY_SCHEMA - com.linkedin.venice.controllerapi.routes.V1Get
 
KEY_SCHEMA - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
KEY_STRING_CLUSTER_NAME - Static variable in class com.linkedin.venice.system.store.MetaStoreWriter
 
KEY_STRING_PARTITION_ID - Static variable in class com.linkedin.venice.system.store.MetaStoreWriter
 
KEY_STRING_SCHEMA_ID - Static variable in class com.linkedin.venice.system.store.MetaStoreWriter
 
KEY_STRING_STORE_NAME - Static variable in class com.linkedin.venice.system.store.MetaStoreWriter
 
KEY_STRING_VERSION_NUMBER - Static variable in class com.linkedin.venice.system.store.MetaStoreWriter
 
KEY_VALUE_PROFILING_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
A config that turns the key/value profiling stats on and off.
KEY_WITH_CHUNKING_SUFFIX_SERIALIZER - Static variable in class com.linkedin.davinci.storage.chunking.ChunkingUtils
 
KEY_ZSTD_COMPRESSION_DICTIONARY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
KeyAndValueSchemas - Class in com.linkedin.venice.utils
 
KeyAndValueSchemas(Schema) - Constructor for class com.linkedin.venice.utils.KeyAndValueSchemas
 
KeyAndValueSchemas(Schema, Schema) - Constructor for class com.linkedin.venice.utils.KeyAndValueSchemas
 
keyBuilder - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
Builder used to build the data path to access Helix internal data.
keyBuilder() - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
keyBytes - Variable in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Avro serialized key
keyBytes - Variable in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Avro serialized key
KEYBYTES_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
keyDeserializer - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
keyEquals(K, K) - Method in class com.linkedin.alpini.base.misc.ArrayMap
 
keyField - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
keyIndex - Variable in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Unique index for each key inside current multi-get request
keyIndex - Variable in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
This index will be used to retrieve the original key from the mapping maintained by Client/Router
keyIndex - Variable in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Unique index for each key inside current multi-get request
keyIndex - Variable in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
The corresponding key index for each record.
KeyInfo(K, byte[], int) - Constructor for class com.linkedin.venice.fastclient.MultiKeyRequestContext.KeyInfo
 
KeyLevelLocksManager - Class in com.linkedin.davinci.kafka.consumer
A helper class to return the same lock for the same raw key bytes.
KeyLevelLocksManager(String, int, int) - Constructor for class com.linkedin.davinci.kafka.consumer.KeyLevelLocksManager
 
keyNum - Variable in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
keySchema - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
keySchema - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
keySchema - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Key schema
keySchemaMap - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
A string to string map representing the mapping from id to key schema.
keySchemaMap - Variable in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
A string to string map representing the mapping from id to key schema.
keySchemaString - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
keySerializer - Variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
keySet() - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns a Set view of the keys contained in this map.
keySet() - Method in class com.linkedin.venice.utils.VeniceProperties
 
KEYSTRING_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
keyStrings - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
An array of Strings to identify the record and create different key spaces within the same metadataType (e.g.
keyStrings - Variable in class com.linkedin.venice.pushstatus.PushStatusKey
Composite key.
keyStrings - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
An array of Strings to identify the record and create different key spaces within the same metadataType (e.g.
keysWithChunkIdSuffix - Variable in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
list of keys associated to all chunks.
KeyWithChunkingSuffixSerializer - Class in com.linkedin.venice.serialization
 
KeyWithChunkingSuffixSerializer() - Constructor for class com.linkedin.venice.serialization.KeyWithChunkingSuffixSerializer
 
KIF_RECORD_READER_KAFKA_CONFIG_PREFIX - Static variable in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
 
kill() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
kill() - Method in interface com.linkedin.venice.hadoop.jobs.ComputeJob
 
kill() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
kill() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
kill() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
KILL - com.linkedin.davinci.kafka.consumer.ConsumerActionType
KILL action has higher priority than others, so that once KILL action is added to the action queue, we will process it immediately to avoid doing throw-away works.
KILL_CONSUMPTION - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
KILL_JOB - com.linkedin.venice.Command
 
KILL_OFFLINE_PUSH_JOB - com.linkedin.venice.authorization.Method
 
KILL_OFFLINE_PUSH_JOB - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
KILL_OFFLINE_PUSH_JOB - com.linkedin.venice.controllerapi.ControllerRoute
 
KILL_PUSH_JOB - com.linkedin.venice.participant.protocol.enums.ParticipantMessageType
 
KILL_WAIT_TIME_MS - Static variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
killConsumptionTask(String) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
killConsumptionTask(String) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
 
killConsumptionTask(String) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
killConsumptionTask(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
killConsumptionTask(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
killConsumptionTask(String) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Kill all of running consumptions of given store.
KILLED - com.linkedin.venice.hadoop.jobs.ComputeJob.Status
A job that was killed
KILLED - com.linkedin.venice.meta.VersionStatus
 
KILLED - com.linkedin.venice.status.protocol.enums.PushJobStatus
 
KILLED - com.linkedin.venice.status.PushJobDetailsStatus
 
KILLED_JOB_MESSAGE - Static variable in class com.linkedin.venice.LogMessages
Replica with ERROR status with the following message implies the job was killed instead of actual ingestion error This is used in server-controller communication to detect killed failed pushes.
killOfflinePush(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
Kill an offline push if it ran into errors or the corresponding version is being retired.
killOfflinePush(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
killOfflinePush(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
killOfflinePushJob(Admin) - Method in class com.linkedin.venice.controller.server.JobRoutes
 
killOfflinePushJob(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
KillOfflinePushJob - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
KillOfflinePushJob() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
Default constructor.
KillOfflinePushJob(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
All-args constructor.
KillOfflinePushMessage - Class in com.linkedin.venice.pushmonitor
 
KillOfflinePushMessage(String) - Constructor for class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
 
KillOfflinePushMessage(Map<String, String>) - Constructor for class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
 
KillPushJob - Class in com.linkedin.venice.participant.protocol
 
KillPushJob() - Constructor for class com.linkedin.venice.participant.protocol.KillPushJob
Default constructor.
KillPushJob(Long) - Constructor for class com.linkedin.venice.participant.protocol.KillPushJob
All-args constructor.
killThreads() - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
KME_REGISTRATION_FROM_MESSAGE_HEADER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
knownProtocols() - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 

L

LAG_MEASUREMENT_FAILURE - com.linkedin.venice.stats.StatsErrorCode
This may be used when kafka topic's offset lag measurement may fail due to any reason.
lagCaughtUp - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Whether lag has ever caught up; it doesn't always indicate the current lag status
lagHasCaughtUp() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
LagType - Enum in com.linkedin.davinci.ingestion
 
LambdaStat - Class in com.linkedin.venice.stats
Deprecated.
, use Gauge instead. The reason to deprecate LambdaStat is that Gauge is a better name when appending the class name as the suffix of metric name here: AbstractVeniceStats.registerSensor(String, Sensor[], MeasurableStat...).
LambdaStat(Measurable, String) - Constructor for class com.linkedin.venice.stats.LambdaStat
Deprecated.
 
LandFillObjectPool<O> - Class in com.linkedin.venice.utils.pools
A dummy implementation which simply allocates a new object on every ObjectPool.get() and lets the garbage collector dispose of it rather than reusing.
LandFillObjectPool(Supplier<O>) - Constructor for class com.linkedin.venice.utils.pools.LandFillObjectPool
 
LARGEST_USED_VERSION_NUMBER - com.linkedin.venice.Arg
 
LARGEST_USED_VERSION_NUMBER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
largestUsedVersionNumber - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
largestUsedVersionNumber - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
largestUsedVersionNumber - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
largestUsedVersionNumber - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
The largest version number ever used before for this store.
largestUsedVersionNumber - Variable in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
last() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
LAST_SUCCEED_EXECUTION_ID - com.linkedin.venice.controllerapi.ControllerRoute
 
lastIndexOf(E, int) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
lastIndexOf(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Searches in this string for the last index of the specified string.
lastIndexOf(CharSequence, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Searches in this string for the index of the specified string.
lastRequest() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
 
LastSucceedExecutionIdResponse - Class in com.linkedin.venice
 
LastSucceedExecutionIdResponse() - Constructor for class com.linkedin.venice.LastSucceedExecutionIdResponse
 
lastUpdate - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
The last time this PartitionState was updated.
LatencyUtils - Class in com.linkedin.venice.utils
 
LatencyUtils() - Constructor for class com.linkedin.venice.utils.LatencyUtils
 
LATEST_SCHEMA_ID_FOR_ADMIN_OPERATION - Static variable in class com.linkedin.venice.controller.kafka.protocol.serializer.AdminOperationSerializer
 
LATEST_SCHEMA_VERSION_FOR_COMPUTE_REQUEST - Static variable in class com.linkedin.venice.compute.ComputeRequestWrapper
 
LATEST_SUPERSET_SCHEMA_ID - com.linkedin.venice.Arg
 
LATEST_SUPERSET_SCHEMA_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
latestMessageConsumptionTimestampInMs - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
the last time when the node consumes any message for this partition
latestSuperSetValueSchemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
The schema id for the latest superset schema
latestSuperSetValueSchemaId - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
latestSuperSetValueSchemaId - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Latest super set value schema ID
latestSuperSetValueSchemaId - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
For read compute stores with auto super-set schema enabled, stores the latest super-set value schema ID.
latestValueSchema - Variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
latestVersionPromoteToCurrentTimestamp - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
This is used to track the time when a new version is promoted to current version.
latestVersionPromoteToCurrentTimestamp - Variable in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
lazy - Variable in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
Lazy<T> - Class in com.linkedin.alpini.base.concurrency
Created by acurtis on 3/29/17.
Lazy<T> - Interface in com.linkedin.venice.utils.lazy
This utility provides lazy initialization for a wrapped object.
LAZY - com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl
Deprecated.
LAZY_WITH_REPLAY_SUPPORT - com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl
Deprecated.
LazyImpl<T> - Class in com.linkedin.venice.utils.lazy
Fork of the LazyInitializer with some additional APIs.
LazyResettable<C> - Interface in com.linkedin.venice.utils.lazy
This, like Lazy, implements the same API as Optional and provides late initialization for its content.
LazyResettableImpl<C> - Class in com.linkedin.venice.utils.lazy
 
LazyResettableImpl(Supplier<C>) - Constructor for class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
LazyResettableWithTearDown<C> - Class in com.linkedin.venice.utils.lazy
 
LazyResettableWithTearDown(Supplier<C>, Consumer<C>) - Constructor for class com.linkedin.venice.utils.lazy.LazyResettableWithTearDown
 
LEADER - com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
This partition is the leader.
LEADER - com.linkedin.venice.helix.HelixState
 
LEADER_BYTES_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
LEADER_BYTES_PRODUCED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
LEADER_COMPLETED - com.linkedin.venice.writer.LeaderCompleteState
Leader partition is completed
LEADER_CONTROLLER - com.linkedin.venice.controllerapi.ControllerRoute
 
LEADER_FOLLOWER_STATE_TRANSITION_THREAD_POOL_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
 
LEADER_NOT_COMPLETED - com.linkedin.venice.writer.LeaderCompleteState
Leader partition is not completed yet: Default state
LEADER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
LEADER_OFFSET_LAG_FILTER - Static variable in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
LEADER_RECORDS_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
LEADER_RECORDS_PRODUCED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
LEADER_STALLED_HYBRID_INGESTION_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
LEADER_STATE - Static variable in enum com.linkedin.venice.helix.HelixState
 
LEADER_TO_STANDBY - com.linkedin.davinci.kafka.consumer.ConsumerActionType
 
LeaderCompleteState - Enum in com.linkedin.venice.writer
Completion state of the leader partition.
LeaderControllerResponse - Class in com.linkedin.venice.controllerapi
 
LeaderControllerResponse() - Constructor for class com.linkedin.venice.controllerapi.LeaderControllerResponse
 
leaderExecuteTopicSwitch(PartitionConsumptionState, TopicSwitch, PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
leaderExecuteTopicSwitch(PartitionConsumptionState, TopicSwitch, PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
LeaderFollowerIngestionProgressNotifier - Class in com.linkedin.davinci.helix
This class used to override VeniceNotifier.catchUpVersionTopicOffsetLag(String, int) to release the latch when the resource is the current version.
LeaderFollowerIngestionProgressNotifier() - Constructor for class com.linkedin.davinci.helix.LeaderFollowerIngestionProgressNotifier
 
leaderFollowerModelEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether or not to use leader follower state transition model for upcoming version
leaderFollowerModelEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
leaderFollowerModelEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
leaderFollowerModelEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not to use leader follower state transition model for upcoming version.
leaderFollowerModelEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Whether or not to use leader follower state transition.
LeaderFollowerPartitionStateModel - Class in com.linkedin.davinci.helix
Venice partition's state model to manage Leader/Follower(Standby) state transitions.
LeaderFollowerPartitionStateModel(VeniceIngestionBackend, VeniceStoreVersionConfig, int, LeaderFollowerIngestionProgressNotifier, ReadOnlyStoreRepository, CompletableFuture<HelixPartitionStatusAccessor>, String, ParticipantStateTransitionStats, HeartbeatMonitoringService) - Constructor for class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
LeaderFollowerPartitionStateModel.LeaderSessionIdChecker - Class in com.linkedin.davinci.helix
A leader session id checker will be created for each consumer action; server checks whether the session id is still valid before processing the consumer action.
LeaderFollowerPartitionStateModelDualPoolFactory - Class in com.linkedin.davinci.helix
 
LeaderFollowerPartitionStateModelDualPoolFactory(VeniceIngestionBackend, VeniceConfigLoader, ExecutorService, ParticipantStateTransitionStats, ExecutorService, ParticipantStateTransitionStats, ReadOnlyStoreRepository, CompletableFuture<HelixPartitionStatusAccessor>, String, HeartbeatMonitoringService) - Constructor for class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelDualPoolFactory
 
LeaderFollowerPartitionStateModelFactory - Class in com.linkedin.davinci.helix
State Transition Handler factory for handling Leader/Follower resources in the storage node.
LeaderFollowerPartitionStateModelFactory(VeniceIngestionBackend, VeniceConfigLoader, ExecutorService, ParticipantStateTransitionStats, ReadOnlyStoreRepository, CompletableFuture<HelixPartitionStatusAccessor>, String, HeartbeatMonitoringService) - Constructor for class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory
 
LeaderFollowerPartitionStateModelFactory.LeaderFollowerThreadPoolStrategy - Enum in com.linkedin.davinci.helix
The leader follower state thread pool strategy specifies how thread pools are allocated for Helix state transition.
leaderFollowerState - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
LeaderFollowerStateType - Enum in com.linkedin.davinci.kafka.consumer
 
LeaderFollowerStoreIngestionTask - Class in com.linkedin.davinci.kafka.consumer
This class contains the state transition work between leader and follower; both leader and follower will keep track of information like which topic leader is consuming from and the corresponding offset as well as the latest successfully consumed or produced offset in the version topic (VT).
LeaderFollowerStoreIngestionTask(StoreIngestionTaskFactory.Builder, Store, Version, Properties, BooleanSupplier, VeniceStoreVersionConfig, int, boolean, Optional<ObjectCacheBackend>, Function<Integer, DaVinciRecordTransformer>) - Constructor for class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
leaderGUID - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
This field is deprecated since GUID is no longer able to identify the split-brain issue once 'pass-through' mode is enabled in venice writer.
leaderHostId - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
An unique identifier (such as host name) that stands for each host.
LeaderMetadata - Class in com.linkedin.venice.kafka.protocol
 
LeaderMetadata() - Constructor for class com.linkedin.venice.kafka.protocol.LeaderMetadata
Default constructor.
LeaderMetadata(CharSequence, Long, Integer) - Constructor for class com.linkedin.venice.kafka.protocol.LeaderMetadata
All-args constructor.
leaderMetadataFooter - Variable in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
A optional footer that leader SN can use to give extra L/F related mete data
LeaderMetadataWrapper - Class in com.linkedin.venice.writer
This is a simple container class to hold Leader metadata related fields together to be passed on to the Put and Delete api in VeniceWriter Caller should construct an instance of this object by properly filling up all the fields of this object.
LeaderMetadataWrapper(long, int) - Constructor for class com.linkedin.venice.writer.LeaderMetadataWrapper
 
leaderOffset - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
The last Kafka offset consumed successfully in this partition from the leader topic.
leaderProducedRecordContext - Variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
LeaderProducedRecordContext - Class in com.linkedin.davinci.kafka.consumer
This class holds all the necessary context information which is passed from kafka consumer thread -> kafka producer callback thread -> drainer thread.
LeaderProducerCallback - Class in com.linkedin.davinci.kafka.consumer
 
LeaderProducerCallback(LeaderFollowerStoreIngestionTask, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, LeaderProducedRecordContext, int, String, long) - Constructor for class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
LeaderSessionIdChecker(long, AtomicLong) - Constructor for class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel.LeaderSessionIdChecker
 
leaderState - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
STANDBY; LEADER; IN_TRANSITION_FROM_STANDBY_TO_LEADER; PAUSE_TRANSITION_FROM_STANDBY_TO_LEADER
leaderTopic - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
The topic that leader is consuming from; for leader, leaderTopic can be different from the version topic; for follower, leaderTopic is the same as version topic.
LeakDetect - Class in com.linkedin.alpini.base.misc
General purpose object reference leak detector with recovery.
LEAKED_PUSH_STATUS_CLEAN_UP_SERVICE_SLEEP_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config defines the sleep interval in leaked push status clean up service.
LEAKED_RESOURCE_ALLOWED_LINGER_TIME_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config defines the allowed linger time for a leaked resource.
leakedAllocations() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocatorMetric
 
LeakedPushStatusCleanUpService - Class in com.linkedin.venice.pushmonitor
LeakedPushStatusCleanUpService will wake up regularly (interval is determined by controller config ConfigKeys.LEAKED_PUSH_STATUS_CLEAN_UP_SERVICE_SLEEP_INTERVAL_MS), get all existing push status ZNodes on Zookeeper that belong to the specified cluster, without scanning through the replica statuses, find all leaked push status and delete them on Zookeeper.
LeakedPushStatusCleanUpService(String, OfflinePushAccessor, ReadOnlyStoreRepository, StoreCleaner, AggPushStatusCleanUpStats, long, long) - Constructor for class com.linkedin.venice.pushmonitor.LeakedPushStatusCleanUpService
 
LeakedResourceCleaner - Class in com.linkedin.venice.cleaner
LeakedResourceCleaner is a background thread which wakes up regularly to release leaked resources from local disk.
LeakedResourceCleaner(StorageEngineRepository, long, ReadOnlyStoreRepository, StoreIngestionService, StorageService, MetricsRepository) - Constructor for class com.linkedin.venice.cleaner.LeakedResourceCleaner
 
LeakedResourceCleanerStats - Class in com.linkedin.venice.stats
LeakedResourceCleanerStats records the occurrences of store resources get removed by LeakedResourceCleaner.
LeakedResourceCleanerStats(MetricsRepository) - Constructor for class com.linkedin.venice.stats.LeakedResourceCleanerStats
 
LEAST_LOADED - com.linkedin.venice.fastclient.meta.ClientRoutingStrategyType
 
LEAST_LOADED - com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategyEnum
This strategy will try to distribute the load to each group according to the capacity of each group.
LEAST_LOADED_ROUTING - com.linkedin.venice.router.api.VeniceMultiKeyRoutingStrategy
 
LeastLoadedClientRoutingStrategy - Class in com.linkedin.venice.fastclient.meta
This strategy is trying to route the request to the least-loaded instances.
LeastLoadedClientRoutingStrategy(InstanceHealthMonitor) - Constructor for class com.linkedin.venice.fastclient.meta.LeastLoadedClientRoutingStrategy
 
LEGACY_AVRO_KEY_FIELD_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
LEGACY_AVRO_VALUE_FIELD_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
LEGACY_CHILD_D2_ZK_HOSTS_PROPERTY - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
LEGACY_VENICE_CHILD_CONTROLLER_D2_SERVICE - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
LEGACY_VENICE_PARENT_CONTROLLER_D2_SERVICE - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
length() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
length() - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
length() - Method in class com.linkedin.venice.utils.ByteArray
 
Level - Class in com.linkedin.alpini.consts
This is the subset of org.apache.log4j.Level and org.apache.log4j.Priority with version 1.2.17 Copied here because slf4j does not have a Level concept
Level(int, String, Predicate<Logger>, Level.Log) - Constructor for class com.linkedin.alpini.consts.Level
Instantiate a Level object.
LifeCycleFilter<T> - Class in com.linkedin.alpini.base.pool.impl
 
LifeCycleFilter(AsyncPool.LifeCycle<T>) - Constructor for class com.linkedin.alpini.base.pool.impl.LifeCycleFilter
 
LifeCycleStatsCollector<T> - Class in com.linkedin.alpini.base.pool.impl
 
LifeCycleStatsCollector(AsyncPool.LifeCycle<T>) - Constructor for class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
LingeringStoreVersionChecker - Interface in com.linkedin.venice.controller.lingeringjob
 
LINKED_BLOCKING_QUEUE - com.linkedin.venice.utils.concurrent.BlockingQueueType
 
LINKED_QUEUE_NODE_OVERHEAD_IN_BYTE - Static variable in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
Considering the node implementation: LinkedList.Node, the overhead is three references, which could be about 24 bytes, and the 'Node' object type itself could take 24 bytes.
LINUX - com.linkedin.alpini.jna.ThreadUtils.OsPlatform
 
LIST_BOOTSTRAPPING_VERSIONS - com.linkedin.venice.Command
 
LIST_BOOTSTRAPPING_VERSIONS - com.linkedin.venice.controllerapi.ControllerRoute
 
LIST_CHILD_CLUSTERS - com.linkedin.venice.controllerapi.ControllerRoute
 
LIST_CLUSTER_STALE_STORES - com.linkedin.venice.Command
 
LIST_CLUSTER_STORAGE_PERSONAS - com.linkedin.venice.Command
 
LIST_NODES - com.linkedin.venice.controllerapi.ControllerRoute
 
LIST_OPS - com.linkedin.venice.schema.writecompute.WriteComputeOperation
Perform list operations on top of the original array.
LIST_OPS_NAME - Static variable in class com.linkedin.venice.schema.writecompute.WriteComputeConstants
 
LIST_REPLICAS - com.linkedin.venice.controllerapi.ControllerRoute
 
LIST_STORAGE_NODES - com.linkedin.venice.Command
 
LIST_STORE_PUSH_INFO - com.linkedin.venice.Command
 
LIST_STORE_PUSH_INFO - com.linkedin.venice.controllerapi.ControllerRoute
 
LIST_STORES - com.linkedin.venice.Command
 
LIST_STORES - com.linkedin.venice.controllerapi.ControllerRoute
 
listAllNodes(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
No ACL check; any user is allowed to list all nodes.
listAllNodesStatus(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
No ACL check; any user is allowed to list all node status.
listAllTopics() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Retrieves a set of all available PubSub topics from the Kafka cluster.
listAllTopics() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Retrieves a set of all available PubSub topics from the PubSub cluster.
listAllTopics() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
listBootstrappingVersions() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listBootstrappingVersions(Admin) - Method in class com.linkedin.venice.controller.server.VersionRoute
No ACL check; any user is allowed to check bootstrapping versions.
listBuilder() - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
listChildControllers(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listConfigs(String) - Static method in class com.linkedin.davinci.config.StoreBackendConfig
 
listener(Promise<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
listener(Promise<V>, Consumer<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
listener(CompletableFuture<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
listener(CompletableFuture<V>, Consumer<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
LISTENER_HOSTNAME - Static variable in class com.linkedin.venice.ConfigKeys
 
LISTENER_PORT - Static variable in class com.linkedin.venice.ConfigKeys
 
LISTENER_SSL_PORT - Static variable in class com.linkedin.venice.ConfigKeys
 
listenerManager - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
ListenerManager<T> - Class in com.linkedin.venice.listener
This class provides the unified way to manager venice listener.
ListenerManager() - Constructor for class com.linkedin.venice.listener.ListenerManager
 
ListenerService - Class in com.linkedin.venice.listener
Service that listens on configured port to accept incoming GET requests
ListenerService(StorageEngineRepository, ReadOnlyStoreRepository, ReadOnlySchemaRepository, CompletableFuture<HelixCustomizedViewOfflinePushRepository>, IngestionMetadataRetriever, ReadMetadataRetriever, VeniceServerConfig, MetricsRepository, Optional<SSLFactory>, Optional<StaticAccessController>, Optional<DynamicAccessController>, DiskHealthCheckService, StorageEngineBackedCompressorFactory, Optional<ResourceReadUsageTracker>) - Constructor for class com.linkedin.venice.listener.ListenerService
 
listEquals(List<T>, List<T>) - Static method in class com.linkedin.venice.utils.CollectionUtils
A manual implementation of list equality.
listInstancesStatuses(boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listIterator(int) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Returns a list-iterator of the elements in this list (in proper sequence), starting at the specified position in the list.
listIterator(int) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
listOf(Collection<T>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
listOf(T) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
listOf(T...) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
listPathContents(ZkBaseDataAccessor<T>, String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
listReplicas(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listReplicasForStorageNode(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
No ACL check; any user is allowed to list replicas in a node.
listReplicasForStore(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
No ACL check; any user is allowed to list replicas for a store.
listStatus(JobConf) - Method in class com.linkedin.venice.hadoop.VsonSequenceFileInputFormat
 
listStorageNodeReplicas(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listStorageNodes() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listStoreNamesFromGraveyard(String) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
 
listStoreNamesFromGraveyard(String) - Method in interface com.linkedin.venice.meta.StoreGraveyard
List store names from graveyard in the specified cluster.
listStorePushInfo(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
listStorePushInfo(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listStorePushInfo(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
listStorePushInfo(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
listStorePushInfo(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
This function will look for a single store, given a name and cluster name, and return information about the current push jobs for that store across all regions.
listStoresStatuses() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
listSubtype() - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
listTopics() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
For tests
listTopics() - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
liveClusterConfig - Variable in class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
 
LiveClusterConfig - Class in com.linkedin.venice.meta
 
LiveClusterConfig() - Constructor for class com.linkedin.venice.meta.LiveClusterConfig
 
LiveClusterConfig(LiveClusterConfig) - Constructor for class com.linkedin.venice.meta.LiveClusterConfig
 
LiveInstanceChangedListener - Interface in com.linkedin.venice.meta
 
LiveInstanceMonitor - Interface in com.linkedin.venice.meta
 
liveInstancesMap - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
liveInstancesMapLock - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
livenessHeartbeatEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
livenessHeartbeatStoreName - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
load() - Method in class com.linkedin.davinci.config.StoreBackendConfig
 
load(Map<String, Object>, SinkContext) - Static method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
loadAllPushes() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
loadAllPushes() - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
load previous push statuses when push monitor restarts
loadAllPushes() - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
loadAllStats() - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
loadAllStats() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatVersionedStats
 
loadClass(String) - Static method in class com.linkedin.venice.utils.ReflectUtils
Load the given class using the default constructor
LOADED_STORE_USER_PARTITION_MAPPING - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to retrieve the loaded store partition mapping in the isolated process.
LoadedStoreUserPartitionMapping - Class in com.linkedin.venice.ingestion.protocol
 
LoadedStoreUserPartitionMapping() - Constructor for class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
Default constructor.
LoadedStoreUserPartitionMapping(Map<CharSequence, List<Integer>>) - Constructor for class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
All-args constructor.
loadFileAsString(String) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
loadFileAsStringQuietlyWithErrorLogged(String) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
loadForkedIngestionKafkaClusterMapConfig(String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
loadFromConfigDirectory(String) - Static method in class com.linkedin.davinci.config.VeniceConfigLoader
 
loadFromEnvironmentVariable() - Static method in class com.linkedin.davinci.config.VeniceConfigLoader
Initializes the Venice configuration service from known environment variables
loadOfflinePushStatusesAndPartitionStatuses() - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
loadOfflinePushStatusesAndPartitionStatuses() - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Load entire database of offline pushes including offline pushes statues and their partitions statuses from persistent storage.
loadOfflinePushStatusPaths() - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
loadOfflinePushStatusPaths() - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Load store versions of all existing push statuses on Zookeeper, without actually deserializing the contents
loadProperties(CommandLine, Arg) - Static method in class com.linkedin.venice.AdminTool
 
loadSchemaFileFromResource(String) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
loadSSLConfig(String) - Static method in class com.linkedin.venice.utils.SslUtils
Build an instance of Properties with a file path to SSL config file.
loadVenicePropertiesFromFile(String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
loadVenicePropertiesFromFile(String, String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
loadZstdTrainingSamples(VeniceRecordIterator, PushJobZstdConfig) - Static method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
This function loads training samples from recordReader abstraction for building the Zstd dictionary.
LOCAL_CONTROLLER_D2_SERVICE_NAME - Static variable in class com.linkedin.venice.ConfigKeys
 
LOCAL_CONTROLLER_URL - Static variable in class com.linkedin.venice.ConfigKeys
The following 3 configs define controller url, d2 service name and d2 zk host in the region that server is located.
LOCAL_D2_ZK_HOST - Static variable in class com.linkedin.venice.ConfigKeys
 
LOCAL_KEYSTORE_JKS - Static variable in class com.linkedin.venice.utils.SslUtils
 
LOCAL_PASSWORD - Static variable in class com.linkedin.venice.utils.SslUtils
Self-signed cert.
LOCAL_REGION_NAME - Static variable in class com.linkedin.venice.ConfigKeys
This config will specify the region name of a controller; the region name can be customized by Venice internal.
LocalBootstrappingVeniceChangelogConsumer<K,​V> - Class in com.linkedin.davinci.consumer
This is a wrapper class on top of InternalBootstrappingVeniceChangelogConsumerImpl.
LocalBootstrappingVeniceChangelogConsumer(ChangelogClientConfig, PubSubConsumerAdapter, String) - Constructor for class com.linkedin.davinci.consumer.LocalBootstrappingVeniceChangelogConsumer
 
localEndpoint(Channel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
localHighWatermarks - Variable in class com.linkedin.venice.kafka.protocol.VersionSwap
The latest offsets of all real-time topic has been consumed up until now.
LOCALHOST - Static variable in class com.linkedin.venice.HttpConstants
 
localKafkaClusterId - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
localKafkaServer - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
localKafkaServerSingletonSet - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
LocalThreadEventLoopGroup<E extends io.netty.channel.MultithreadEventLoopGroup> - Class in com.linkedin.alpini.netty4.misc
A specialised EventLoopGroup which the MultithreadEventLoopGroup.next() method prefers to return an EventLoop for the current thread, if the current thread is a thread of the wrapped MultithreadEventLoopGroup.
LocalThreadEventLoopGroup(E) - Constructor for class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
localThreadGroup() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
localThreadGroup(EventLoop) - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
lock() - Method in class com.linkedin.venice.utils.VeniceLock
Attempt to acquire the lock.
lockAcquisitionTimeMs - Variable in class com.linkedin.venice.stats.VeniceLockStats
 
LOCKED_NODE_ID_LIST_SEPARATOR - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
LOCKED_STORAGE_NODE_IDS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
lockForShutdown() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
Lock the resource for shutdown operation(leadership handle over and controller shutdown).
lockRetentionTimeMs - Variable in class com.linkedin.venice.stats.VeniceLockStats
 
log(Level, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
log(Level, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
LOG - Static variable in class com.linkedin.alpini.io.ExternalCommand
 
LOG - Static variable in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
LOG - Static variable in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
LOG - Static variable in class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
LOG_COMPACTION_ENABLED - Static variable in class com.linkedin.venice.views.ViewUtils
 
LOG_DATA_RECORD - com.linkedin.venice.Arg
 
LOG_METADATA - com.linkedin.venice.Arg
 
LOG_RMD_RECORD - com.linkedin.venice.Arg
 
Log4J2FrameLogger - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 4/19/18.
Log4J2FrameLogger(Level) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
Log4J2FrameLogger(Level, Class<?>) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
Log4J2FrameLogger(Level, String) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
Log4J2LoggingHandler - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 4/20/18.
Log4J2LoggingHandler() - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
Creates a new instance whose logger name is the fully qualified class name of the instance with hex dump enabled.
Log4J2LoggingHandler(LogLevel) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
Creates a new instance whose logger name is the fully qualified class name of the instance.
Log4J2LoggingHandler(Class<?>) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
Creates a new instance with the specified logger name and with hex dump enabled.
Log4J2LoggingHandler(Class<?>, LogLevel) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
Creates a new instance with the specified logger name.
Log4J2LoggingHandler(String) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
Creates a new instance with the specified logger name using the default log level.
Log4J2LoggingHandler(String, LogLevel) - Constructor for class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
Creates a new instance with the specified logger name.
logClassLoaderContent(String) - Static method in class com.linkedin.venice.utils.ExceptionUtils
 
LogConfigurator - Class in com.linkedin.venice
 
LogConfigurator() - Constructor for class com.linkedin.venice.LogConfigurator
 
logConfiguredValues(T) - Method in class com.linkedin.alpini.cli.CLIArgumentParser
Log the configured values.
logConfiguredValues(T) - Method in interface com.linkedin.alpini.cli.CLIParser
 
logData(Http2FrameLogger.Direction, ChannelHandlerContext, int, ByteBuf, int, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logData(Http2FrameLogger.Direction, ChannelHandlerContext, int, ByteBuf, int, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logger - Variable in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
logger - Variable in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
logger - Variable in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
logger - Variable in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
logger - Variable in class com.linkedin.venice.service.AbstractVeniceService
 
LOGGER - Static variable in class com.linkedin.venice.controller.systemstore.SystemStoreRepairService
 
LOGGER - Static variable in class com.linkedin.venice.controller.systemstore.SystemStoreRepairTask
 
LOGGER - Static variable in class com.linkedin.venice.controller.util.ParentControllerConfigUpdateUtils
 
logGoAway(Http2FrameLogger.Direction, ChannelHandlerContext, int, long, ByteBuf) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logGoAway(Http2FrameLogger.Direction, ChannelHandlerContext, int, long, ByteBuf) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logHeaders(Http2FrameLogger.Direction, ChannelHandlerContext, int, Http2Headers, int, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logHeaders(Http2FrameLogger.Direction, ChannelHandlerContext, int, Http2Headers, int, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logHeaders(Http2FrameLogger.Direction, ChannelHandlerContext, int, Http2Headers, int, short, boolean, int, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logHeaders(Http2FrameLogger.Direction, ChannelHandlerContext, int, Http2Headers, int, short, boolean, int, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logicalTimestamp - Variable in class com.linkedin.venice.kafka.protocol.ProducerMetadata
This timestamp may be specified by the user.
logIfEnabled(String, Level, Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
logIfEnabled(String, Level, Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
LogInfo() - Constructor for class com.linkedin.venice.utils.ForkedJavaProcess.LogInfo
 
logInitializingHttp1(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
logInitializingHttp2(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
logMessage(String, Level, Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
logMessageProgress() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
LogMessages - Class in com.linkedin.venice
 
LogMessages() - Constructor for class com.linkedin.venice.LogMessages
 
LogNotifier - Class in com.linkedin.davinci.notifier
Logs the Notification received.
LogNotifier() - Constructor for class com.linkedin.davinci.notifier.LogNotifier
 
LOGO - com.linkedin.venice.utils.TestWriteUtils.TestTargetedField
 
logPing(Http2FrameLogger.Direction, ChannelHandlerContext, long) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logPing(Http2FrameLogger.Direction, ChannelHandlerContext, long) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logPingAck(Http2FrameLogger.Direction, ChannelHandlerContext, long) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logPingAck(Http2FrameLogger.Direction, ChannelHandlerContext, long) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logPriority(Http2FrameLogger.Direction, ChannelHandlerContext, int, int, short, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logPriority(Http2FrameLogger.Direction, ChannelHandlerContext, int, int, short, boolean) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logPushPromise(Http2FrameLogger.Direction, ChannelHandlerContext, int, int, Http2Headers, int) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logPushPromise(Http2FrameLogger.Direction, ChannelHandlerContext, int, int, Http2Headers, int) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logRstStream(Http2FrameLogger.Direction, ChannelHandlerContext, int, long) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logRstStream(Http2FrameLogger.Direction, ChannelHandlerContext, int, long) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logSettings(Http2FrameLogger.Direction, ChannelHandlerContext, Http2Settings) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logSettingsAck(Http2FrameLogger.Direction, ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
LogSslCipherSuiteHandler - Class in com.linkedin.alpini.netty4.handlers
 
LogSslCipherSuiteHandler() - Constructor for class com.linkedin.alpini.netty4.handlers.LogSslCipherSuiteHandler
 
logStorageOperationWhileUnsubscribed(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
logUnknownFrame(Http2FrameLogger.Direction, ChannelHandlerContext, byte, int, Http2Flags, ByteBuf) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logUnknownFrame(Http2FrameLogger.Direction, ChannelHandlerContext, byte, int, Http2Flags, ByteBuf) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logWindowsUpdate(Http2FrameLogger.Direction, ChannelHandlerContext, int, int) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
logWindowsUpdate(Http2FrameLogger.Direction, ChannelHandlerContext, int, int) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2FrameLogger
 
logWithLevel(Logger, Level, String, Object...) - Static method in class com.linkedin.alpini.consts.Level
Log at the specified level.
long_field - Variable in class com.linkedin.venice.client.store.schemas.TestKeyRecord
 
long_field - Variable in class com.linkedin.venice.client.store.schemas.TestValueRecord
 
long_field - Variable in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
LONG_TYPE_TIMESTAMP_SCHEMA - Static variable in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
LongAdderRateGauge - Class in com.linkedin.venice.stats
This metric class is to optimize for high write throughput, low read throughput measurement use case instead of real-time measurement.
LongAdderRateGauge() - Constructor for class com.linkedin.venice.stats.LongAdderRateGauge
 
LongAdderRateGauge(Time) - Constructor for class com.linkedin.venice.stats.LongAdderRateGauge
 
LongData() - Constructor for class com.linkedin.alpini.base.statistics.LongStatsAggregator.LongData
 
LongEqualOrGreaterThanMatcher - Class in com.linkedin.venice.unit.matchers
 
LongEqualOrGreaterThanMatcher(long) - Constructor for class com.linkedin.venice.unit.matchers.LongEqualOrGreaterThanMatcher
 
longOpt() - Method in annotation type com.linkedin.alpini.cli.CLIArgument
Long name for the option.
longOpt() - Method in annotation type com.linkedin.alpini.cli.CLIFlag
Long name for the option.
LongQuantileArrayEstimation - Class in com.linkedin.alpini.base.statistics
 
LongQuantileArrayEstimation(double, int) - Constructor for class com.linkedin.alpini.base.statistics.LongQuantileArrayEstimation
 
LongQuantileEstimation - Class in com.linkedin.alpini.base.statistics
 
LongQuantileEstimation(double, int) - Constructor for class com.linkedin.alpini.base.statistics.LongQuantileEstimation
 
LongQuantileEstimation.Sample - Class in com.linkedin.alpini.base.statistics
 
LongStats - Interface in com.linkedin.alpini.base.statistics
 
LongStatsAggregator - Class in com.linkedin.alpini.base.statistics
Extend the LongQuantileEstimation class and add computation for the mean and standard deviation of the supplied values.
LongStatsAggregator(double, int) - Constructor for class com.linkedin.alpini.base.statistics.LongStatsAggregator
 
LongStatsAggregator.LongData - Class in com.linkedin.alpini.base.statistics
 
LongStatsAggregatorLowQuantile - Class in com.linkedin.alpini.base.statistics
Extend the LongStatsAggregator class to only track low quantile points.
LongStatsAggregatorLowQuantile(double, int) - Constructor for class com.linkedin.alpini.base.statistics.LongStatsAggregatorLowQuantile
 
LongStatsArrayAggregator - Class in com.linkedin.alpini.base.statistics
Extend the LongQuantileEstimation class and add computation for the mean and standard deviation of the supplied values.
LongStatsArrayAggregator(double, int) - Constructor for class com.linkedin.alpini.base.statistics.LongStatsArrayAggregator
 
LongStatsLowQuantile - Interface in com.linkedin.alpini.base.statistics
 
LongStatsLowQuantileImpl - Class in com.linkedin.alpini.base.statistics
 
longTailMinimumMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
LongTailRetryStatsProvider - Class in com.linkedin.venice.router.stats
This class is a stats generator for dds router framework to record scattering/gathering related metrics.
LongTailRetryStatsProvider(RouterStats<AggRouterHttpRequestStats>) - Constructor for class com.linkedin.venice.router.stats.LongTailRetryStatsProvider
 
longTailRetrySupplier(LongTailRetrySupplier<P, K>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
LongTailRetrySupplier<P extends ResourcePath<K>,​K> - Interface in com.linkedin.alpini.router.api
 
LongWelford() - Constructor for class com.linkedin.alpini.base.statistics.Welfords.LongWelford
 
LongWelford(Welfords.LongWelford) - Constructor for class com.linkedin.alpini.base.statistics.Welfords.LongWelford
 
lookupName(CharSequence) - Method in class com.linkedin.alpini.base.misc.HeaderStringCache.Cache
Header names are cached case insensitive.
lookupValue(CharSequence) - Method in class com.linkedin.alpini.base.misc.HeaderStringCache.Cache
Header values are cached case sensitive.
lookupWriterField(Schema, Schema.Field) - Static method in class com.linkedin.venice.schema.avro.SchemaCompatibility
Identifies the writer field that corresponds to the specified reader field.
LOW - com.linkedin.alpini.consts.QOS
 
LowerCaseAsciiCharSequence - Class in com.linkedin.alpini.base.misc
 
LowerCaseAsciiCharSequence(CharSequence) - Constructor for class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
LOWEST_OFFSET - Static variable in class com.linkedin.venice.offsets.OffsetRecord
 
LOWEST_OFFSET_LAG - Static variable in class com.linkedin.venice.offsets.OffsetRecord
 
lowWatermark - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
EOIP control message timestamp of the most recent incremental push that has been marked successful
LRU - com.linkedin.davinci.store.rocksdb.RocksDBBlockCacheImplementations
Each shard of the cache maintains its own LRU list and its own hash table for lookup.

M

main(String[]) - Static method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
main(String[]) - Static method in class com.linkedin.venice.AdminTool
 
main(String[]) - Static method in class com.linkedin.venice.client.store.QueryTool
 
main(String[]) - Static method in class com.linkedin.venice.controller.VeniceController
 
main(String[]) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
 
main(String[]) - Static method in class com.linkedin.venice.producer.online.ProducerTool
 
main(String[]) - Static method in class com.linkedin.venice.router.RouterServer
 
main(String[]) - Static method in class com.linkedin.venice.server.VeniceServer
 
main(String[]) - Static method in class com.linkedin.venice.standalone.VeniceStandalone
 
MAIN - com.linkedin.davinci.ingestion.main.MainPartitionIngestionStatus
 
MainIngestionMonitorService - Class in com.linkedin.davinci.ingestion.main
This class is the listener service in main process which handles various kinds of reports sent from isolated ingestion service.
MainIngestionMonitorService(IsolatedIngestionBackend, VeniceConfigLoader) - Constructor for class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
MainIngestionReportChannelInitializer - Class in com.linkedin.davinci.ingestion.main
 
MainIngestionReportChannelInitializer(MainIngestionMonitorService, Optional<SSLFactory>) - Constructor for class com.linkedin.davinci.ingestion.main.MainIngestionReportChannelInitializer
 
MainIngestionReportHandler - Class in com.linkedin.davinci.ingestion.main
This class is the handler class for MainIngestionMonitorService.
MainIngestionReportHandler(MainIngestionMonitorService) - Constructor for class com.linkedin.davinci.ingestion.main.MainIngestionReportHandler
 
MainIngestionRequestClient - Class in com.linkedin.davinci.ingestion.main
This class sends requests to isolated ingestion process and retrieves responses.
MainIngestionRequestClient(VeniceConfigLoader) - Constructor for class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
MainIngestionStorageMetadataService - Class in com.linkedin.davinci.ingestion.main
MainIngestionStorageMetadataService is an in-memory storage metadata service for IsolatedIngestionBackend.
MainIngestionStorageMetadataService(int, InternalAvroSpecificSerializer<PartitionState>, MetadataUpdateStats, VeniceConfigLoader, BiConsumer<String, StoreVersionState>) - Constructor for class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
MainPartitionIngestionStatus - Enum in com.linkedin.davinci.ingestion.main
 
MainTopicIngestionStatus - Class in com.linkedin.davinci.ingestion.main
This class manages the ingestion status for each partition for a given topic when isolated ingestion is enabled.
MainTopicIngestionStatus(String) - Constructor for class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
make(ScatterGatherHelper<H, P, K, R, ?, ?, ?>, TimeoutProcessor, Executor) - Static method in class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
make(ScatterGatherHelper<H, P, K, R, ?, ?, ?>, RouterTimeoutProcessor, Executor) - Static method in class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
make(F, S) - Static method in class com.linkedin.alpini.base.misc.Pair
Make a Pair.
make(Runnable) - Static method in class com.linkedin.alpini.base.concurrency.RunOnce
 
make(Supplier<?>) - Static method in class com.linkedin.alpini.base.misc.Msg
 
make(Map.Entry<K, V>) - Static method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
 
make(K, V) - Static method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
 
make(T, Consumer<T>) - Static method in class com.linkedin.alpini.base.concurrency.RunOnce
 
make(T, Function<T, ?>) - Static method in class com.linkedin.alpini.base.misc.Msg
 
makeClientContext(long, long) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeClientContext(long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeClientContext(Object, String, String, File, String, long, long) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeClientContext(Object, String, String, File, String, long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeClientContext(Provider, long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeClientContext(Provider, long, long, boolean, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeClientContext(Provider, Object, String, String, File, String, long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeClientContext(Provider, Object, String, String, File, String, long, long, boolean, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeLargeNumberPretty(long) - Static method in class com.linkedin.venice.utils.Utils
 
makeNullable(T, Function<T, ?>) - Static method in class com.linkedin.alpini.base.misc.Msg
 
makeServerContext(long, long) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeServerContext(long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeServerContext(Object, String, String, File, String, long, long) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeServerContext(Object, String, String, File, String, long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeServerContext(Provider, long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeServerContext(Provider, long, long, boolean, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeServerContext(Provider, Object, String, String, File, String, long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeServerContext(Provider, Object, String, String, File, String, long, long, boolean, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
makeSureRocksDBIsStillOpen() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
makeTimePretty(long) - Static method in class com.linkedin.venice.utils.Utils
 
makeTransitionCompleted(String, int) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
 
makeTransitionError(String, int) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
 
ManagedChannelPool - Interface in com.linkedin.alpini.netty4.pool
 
managedClients - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
manager - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
Manager used to communicate with Helix.
map(INPUT_KEY, INPUT_VALUE, OutputCollector<BytesWritable, BytesWritable>, Reporter) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.map.AbstractVeniceMapper
 
map(Function<? super C, ? extends U>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
map(Function<? super T, ? extends U>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
If a value is initialized, apply the provided mapping function to it, and if the result is non-null, return an Optional describing the result.
map(Function<? super T, ? extends U>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
map(Iterator<T>, Function<? super T, ? extends R>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
map(IntWritable, NullWritable, OutputCollector<AvroWrapper<SpecificRecord>, NullWritable>, Reporter) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
MAP_DIFF - Static variable in class com.linkedin.venice.schema.writecompute.WriteComputeConstants
 
MAP_OPS - com.linkedin.venice.schema.writecompute.WriteComputeOperation
Perform map operations on top of the original map.
MAP_OPS_NAME - Static variable in class com.linkedin.venice.schema.writecompute.WriteComputeConstants
 
MAP_REDUCE_JOB_ID_PROP - Static variable in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
MAP_REDUCE_PARTITIONER_CLASS_CONFIG - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config used only for tests.
MAP_UNION - Static variable in class com.linkedin.venice.schema.writecompute.WriteComputeConstants
 
mapBuilder() - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
mapIterator(Iterator<T>, Function<T, O>) - Static method in class com.linkedin.venice.utils.IteratorUtils
 
mapJSON(String) - Static method in enum com.linkedin.alpini.base.misc.SimpleJsonMapper
Converts valid JSON document into a hash map of Strings.
mapNext() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
mapOf(K, V) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
mapOf(K, V, K, V) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
mapOf(K, V, K, V, K, V) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
mapOf(K, V, K, V, K, V, K, V) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
mapOfEntries(ImmutableMapEntry<K, V>...) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
MapOrderPreservingDatumReader<T> - Class in com.linkedin.davinci.serializer.avro
MapOrderPreservingDatumReader converts map type serialized items into instances with a consistent ordering of entries.
MapOrderPreservingDatumReader(Schema, Schema) - Constructor for class com.linkedin.davinci.serializer.avro.MapOrderPreservingDatumReader
 
MapOrderPreservingDeserializer - Class in com.linkedin.davinci.serializer.avro
MapOrderPreservingDeserializer is a Avro deserializer using MapOrderPreservingDatumReader.
MapOrderPreservingFastDeserializer - Class in com.linkedin.davinci.serializer.avro.fast
 
MapOrderPreservingFastDeserializer(Schema, Schema) - Constructor for class com.linkedin.davinci.serializer.avro.fast.MapOrderPreservingFastDeserializer
 
MapOrderPreservingFastSerDeFactory - Class in com.linkedin.davinci.serializer.avro.fast
Factory to create fast serializer/deserializer of supporting map ordering.
MapOrderPreservingFastSerDeFactory() - Constructor for class com.linkedin.davinci.serializer.avro.fast.MapOrderPreservingFastSerDeFactory
 
MapOrderPreservingFastSerializer<K> - Class in com.linkedin.davinci.serializer.avro.fast
 
MapOrderPreservingFastSerializer(Schema) - Constructor for class com.linkedin.davinci.serializer.avro.fast.MapOrderPreservingFastSerializer
 
MapOrderPreservingGenericDatumWriter<T> - Class in com.linkedin.davinci.serializer.avro
MapOrderPreservingGenericDatumWriter converts map type instances to in-memory serialized format * with a consistent ordering of map entries.
MapOrderPreservingGenericDatumWriter(Schema) - Constructor for class com.linkedin.davinci.serializer.avro.MapOrderPreservingGenericDatumWriter
 
MapOrderPreservingSerDeFactory - Class in com.linkedin.davinci.serializer.avro
This class is a factory that creates MapOrderPreservingSerializer and MapOrderPreservingDeserializer with given schemas and cache them.
MapOrderPreservingSerDeFactory() - Constructor for class com.linkedin.davinci.serializer.avro.MapOrderPreservingSerDeFactory
 
MapOrderPreservingSerializer<K> - Class in com.linkedin.davinci.serializer.avro
MapOrderPreservingSerializer is AvroSerializer that maintains a consistent ordering of map entries by using MapOrderPreservingGenericDatumWriter and MapOrderPreservingSpecificDatumWriter.
MapOrderPreservingSpecificDatumWriter<T> - Class in com.linkedin.davinci.serializer.avro
MapOrderPreservingSpecificDatumWriter converts map type instances to in-memory serialized format with a consistent ordering of map entries.
MapOrderPreservingSpecificDatumWriter(Schema) - Constructor for class com.linkedin.davinci.serializer.avro.MapOrderPreservingSpecificDatumWriter
 
MAPPER_ERROR_DATA_MODIFIED_DURING_PUSH_JOB_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_INVALID_INPUT_FILE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_INVALID_INPUT_IDX_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_NUM_RECORDS_SUCCESSFULLY_PROCESSED_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_OUTPUT_DIRECTORY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
MAPPER_SCHEMA_INCONSISTENCY_FAILURE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_SPRAY_ALL_PARTITIONS_TRIGGERED_COUNT_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_ZSTD_DICT_TRAIN_FAILURE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_ZSTD_DICT_TRAIN_SKIPPED_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MAPPER_ZSTD_DICT_TRAIN_SUCCESS_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
MapperValueType - Enum in com.linkedin.venice.hadoop.input.kafka.avro
 
MAPRED_TASK_ID_PROP_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
 
MAPREDUCE_JOB_NAME_PROP_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
 
MapReduceEngineTaskConfigProvider - Class in com.linkedin.venice.hadoop.mapreduce.engine
An implementation of EngineTaskConfigProvider to get information about a running job on the MapReduce engine.
MapReduceEngineTaskConfigProvider(JobConf) - Constructor for class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
 
markChannelAvailableForReuse(Http2StreamChannel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
markChannelForReuse(Http2StreamChannel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Mark a stream to indicate that it will be reused.
markOfflinePushAsError(String, String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
markOfflinePushAsError(String, String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Mark a push to be as error.
markOfflinePushAsError(String, String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
markStorageNodeAsFast(String) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
mask(int) - Static method in class com.linkedin.alpini.base.hash.Crc32C
Return a masked representation of crc.
maskedCrc32c(byte[]) - Static method in class com.linkedin.alpini.base.hash.Crc32C
 
maskedCrc32c(byte[], int, int) - Static method in class com.linkedin.alpini.base.hash.Crc32C
 
MASTER_CONTROLLER - com.linkedin.venice.controllerapi.ControllerRoute
Deprecated.
matches(Exception) - Method in class com.linkedin.venice.unit.matchers.ExceptionClassAndCauseClassMatcher
 
matches(Exception) - Method in class com.linkedin.venice.unit.matchers.ExceptionClassMatcher
 
matches(Long) - Method in class com.linkedin.venice.unit.matchers.LongEqualOrGreaterThanMatcher
 
matches(String) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Determines whether this string matches a given regular expression.
matches(String) - Method in class com.linkedin.venice.unit.matchers.NonEmptyStringMatcher
 
materializeSystemStore(VeniceParentHelixAdmin, String, String, String) - Static method in class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
 
materializeSystemStoresForUserStore(String, String) - Method in class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
 
MAX_ALLOWED_GROUP - Static variable in class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
 
MAX_ATTEMPTS_FOR_SCHEMA_READER - Static variable in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
MAX_ATTEMPTS_WHEN_TOPIC_MISSING - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
MAX_COMPACTION_LAG_SECONDS - com.linkedin.venice.Arg
 
MAX_COMPACTION_LAG_SECONDS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
MAX_ELAPSED_TIME_FOR_SEGMENT_IN_MS - Static variable in class com.linkedin.venice.writer.VeniceWriter
A negative value or 0 will disable the feature.
MAX_FUTURE_VERSION_LEADER_FOLLOWER_STATE_TRANSITION_THREAD_NUMBER - Static variable in class com.linkedin.venice.ConfigKeys
 
MAX_HISTORY_LENGTH - Static variable in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
MAX_LEADER_FOLLOWER_STATE_TRANSITION_THREAD_NUMBER - Static variable in class com.linkedin.venice.ConfigKeys
 
MAX_MESSAGES_PROPERTY - Static variable in class com.linkedin.alpini.base.misc.TouchTimer
 
MAX_ONLINE_OFFLINE_STATE_TRANSITION_THREAD_NUMBER - Static variable in class com.linkedin.venice.ConfigKeys
 
MAX_POLL_ATTEMPTS - com.linkedin.venice.Arg
 
MAX_PUSH_TO_KEEP - Static variable in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
MAX_READ_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
 
MAX_SIZE_FOR_USER_PAYLOAD_PER_MESSAGE_IN_BYTES - Static variable in class com.linkedin.venice.writer.VeniceWriter
Chunk size.
maxChunkSize(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
maxChunkSize(int) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
maxChunkSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
maxChunkSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
maxCompactionLagSeconds - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Store-level version topic max compaction lag
maxCompactionLagSeconds - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Store level max compaction lag config and if not specified, 'max.compaction.lag.ms' config won't be setup in the corresponding version topics
maxConnectionsPerRoute - Variable in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
maxConnectionsTotal - Variable in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
maxContentLength() - Method in class io.netty.handler.codec.EspressoMessageAggregator
Returns the maximum allowed length of the aggregated message in bytes.
maxContentLength(long) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
maxContentLength(long) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
maxContentLength(long) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
maxCumulationBufferComponents() - Method in class io.netty.handler.codec.EspressoMessageAggregator
Returns the maximum number of components in the cumulation buffer.
maxHeaderSize(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
maxHeaderSize(int) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
maxHeaderSize(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
maxHeaderSize(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
MAXIMUM_ACTIVE_STREAMS_VIOLATED_MSG - Static variable in class com.linkedin.alpini.netty4.misc.Http2Utils
 
maxInitialLineLength(int) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
maxInitialLineLength(int) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
maxInitialLineLength(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
maxInitialLineLength(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
maxWritableBytes() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
maybeCompressData(int, ByteBuffer, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
Compresses data in a bytebuffer when consuming from rt as a leader node and compression is enabled for the store version for which we're consuming data.
maybeCreateSystemStoreWildcardAcl(String) - Method in class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
 
maybeDeleteSystemStoresForUserStore(VeniceHelixAdmin, ReadWriteStoreRepository, PushMonitorDelegator, String, Store, MetaStoreWriter, Logger) - Static method in class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
 
maybeInitializeResourceHostingMetadata(String, int) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
maybeSendIngestionHeartbeat() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
For hybrid stores only, the leader periodically writes a special SOS message to the RT topic with the following properties:
1.
maybeSendIngestionHeartbeat() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
For L/F hybrid stores, the leader periodically writes a special SOS message to the RT topic.
maybeThrottle(double) - Method in class com.linkedin.venice.throttle.EventThrottler
Sleeps if necessary to slow down the caller.
maybeUpdateExpectedChecksum(byte[], Put) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
Keep updating the checksum for key/value pair received from kafka PUT message.
mayRemoveTransientRecord(int, long, byte[]) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
This operation is performed atomically to delete the record only when the provided sourceOffset matches.
mayThrottleRead(String, double) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
Check the quota and reject the request if needed.
mayThrottleRead(String, double) - Method in interface com.linkedin.venice.router.throttle.RouterThrottler
Returns if the request should be allowed, throws a com.linkedin.venice.exceptions.QuotaExceededException if the request is out of quota.
MD5 - com.linkedin.venice.kafka.validation.checksum.CheckSumType
 
MD5_HASH_ALGORITHM - Static variable in class com.linkedin.venice.partitioner.DefaultVenicePartitioner
 
MD5CheckSum - Class in com.linkedin.venice.kafka.validation.checksum
Running checksum implementation based on BouncyCastle's implementation of MD5.
MD5CheckSum() - Constructor for class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
 
MD5CheckSum(byte[]) - Constructor for class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
 
Measurable - Interface in com.linkedin.venice.common
 
measure(MetricConfig, long) - Method in class com.linkedin.venice.stats.LongAdderRateGauge
 
measureHybridOffsetLag(PartitionConsumptionState, boolean) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
For Leader/Follower state model, we already keep track of the consumption progress in leader, so directly calculate the lag with the real-time topic and the leader consumption offset.
measureHybridOffsetLag(PartitionConsumptionState, boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Measure the hybrid offset lag for partition being tracked in `partitionConsumptionState`.
measureLagWithCallToPubSub(String, PubSubTopic, int, long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
measureLagWithCallToPubSub(String, PubSubTopic, int, long, Function<String, TopicManager>) - Static method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
measureRTOffsetLagForMultiRegions(Set<String>, PartitionConsumptionState, boolean) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
For stores in aggregate mode this is optimistic and returns the minimum lag of all fabric.
measureRTOffsetLagForMultiRegions(Set<String>, PartitionConsumptionState, boolean) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
measureRTOffsetLagForSingleRegion(String, PartitionConsumptionState, boolean) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
This method fetches/calculates latest leader persisted offset and last offset in RT topic.
meetsAny(int, Predicate<Integer>) - Method in class com.linkedin.davinci.kafka.consumer.AmplificationFactorAdapter
This method returns True when the predicate is tested True for any of the subPartition in the user partition.
MEMORY_BACKED_BY_DISK - com.linkedin.davinci.client.StorageClass
The mode has the following implications: 1.
memoryAddress() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
MemoryBoundBlockingQueue<T extends Measurable> - Class in com.linkedin.davinci.kafka.consumer
This class is a generic implementation of a memory bound blocking queue.
MemoryBoundBlockingQueue(long, long) - Constructor for class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
MemoryLimitExhaustedException - Exception in com.linkedin.venice.exceptions
 
MemoryLimitExhaustedException(String) - Constructor for exception com.linkedin.venice.exceptions.MemoryLimitExhaustedException
 
MemoryLimitExhaustedException(String, int, long) - Constructor for exception com.linkedin.venice.exceptions.MemoryLimitExhaustedException
 
merge(Welfords) - Method in class com.linkedin.alpini.base.statistics.Welfords
 
merge(StoreDataAudit) - Method in class com.linkedin.venice.meta.StoreDataAudit
 
merge(K, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
merge(SAMPLE, boolean, boolean) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.AbstractSample
 
Merge<T> - Interface in com.linkedin.davinci.replication.merge
API for merging existing data with incoming writes.
MergeByteBuffer - Class in com.linkedin.davinci.replication.merge
This class handles byte-level merge.
MergeByteBuffer() - Constructor for class com.linkedin.davinci.replication.merge.MergeByteBuffer
 
mergeConfigs(List<Map<String, String>>) - Static method in class com.linkedin.venice.utils.TestUtils
 
MergeConflictResolver - Class in com.linkedin.davinci.replication.merge
The workflow is Query old replication metadata.
MergeConflictResolverFactory - Class in com.linkedin.davinci.replication.merge
 
MergeConflictResult - Class in com.linkedin.davinci.replication.merge
An object to encapsulate the results of conflict resolution to denote how the operation and value that should be applied or if the current update should be ignored.
MergeConflictResult(ByteBuffer, int, boolean, GenericRecord) - Constructor for class com.linkedin.davinci.replication.merge.MergeConflictResult
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
mergeFrom(CodedInputStream, ExtensionRegistryLite) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
mergeFrom(Message) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
mergeFrom(Message) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
mergeFrom(VeniceClientRequest) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
mergeFrom(VeniceServerResponse) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
MergeGenericRecord - Class in com.linkedin.davinci.replication.merge
Implementations of the API defined in Merge based on V1 metadata timestamp Schema generated by RmdSchemaGeneratorV1.
MergeGenericRecord(WriteComputeProcessor, MergeRecordHelper) - Constructor for class com.linkedin.davinci.replication.merge.MergeGenericRecord
 
mergeNewSettingsIntoOldHybridStoreConfig(Store, Optional<Long>, Optional<Long>, Optional<Long>, Optional<DataReplicationPolicy>, Optional<BufferReplayPolicy>) - Static method in class com.linkedin.venice.controller.VeniceHelixAdmin
Used by both the VeniceHelixAdmin and the VeniceParentHelixAdmin
MergeRecordHelper - Interface in com.linkedin.davinci.schema.merge
The purpose of this interface is to extract common merge logic.
MergeResultValueSchemaResolverImpl - Class in com.linkedin.davinci.replication.merge
 
MergeResultValueSchemaResolverImpl(StringAnnotatedStoreSchemaCache, String) - Constructor for class com.linkedin.davinci.replication.merge.MergeResultValueSchemaResolverImpl
 
mergeUnknownFields(UnknownFieldSet) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
mergeUnknownFields(UnknownFieldSet) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
MergeUtils - Class in com.linkedin.davinci.replication.merge
 
message - Variable in class com.linkedin.venice.datarecovery.Command.Result
 
message - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
MESSAGE_COUNT - com.linkedin.venice.Arg
 
messageId - Variable in class com.linkedin.venice.status.StatusMessage
 
messageSequenceNumber - Variable in class com.linkedin.venice.kafka.protocol.ProducerMetadata
A monotonically increasing number with no gaps used to distinguish unique messages produced in this segment (i.e.: by this producer into a given partition).
messageSequenceNumber - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The current message sequence number, within the current segment, which we have seen for this partition/producer pair.
messageSequenceNumber - Variable in class com.linkedin.venice.storage.protocol.ChunkId
The sequence number of the first chunk sent as part of this multi-chunk value.
messageTimestamp - Variable in class com.linkedin.venice.kafka.protocol.ProducerMetadata
The time of the producer's local system clock, at the time the message was submitted for production.
messageTimestamp - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The timestamp included in the last message we have seen for this partition/producer pair.
messageType - Variable in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Using int because Avro Enums are not evolvable.
messageType - Variable in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
0 => KillPushJob
messageType - Variable in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
0 => KillPushJob
messageType - Variable in class com.linkedin.venice.pushstatus.PushStatusKey
0 -> Heartbeat Message, 1 -> Full Push, 2 -> Da-Vinci Incremental Push, 3 -> Server Incremental Push, 4 -> All Incremental Push Statuses.
MessageType - Enum in com.linkedin.venice.kafka.protocol.enums
A simple enum to map the values of KafkaMessageEnvelope.messageType N.B.: We maintain this enum manually because Avro's auto-generated enums do not support evolution (i.e.: adding values) properly.
MessageType.Constants - Class in com.linkedin.venice.kafka.protocol.enums
 
messageUnion - Variable in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
This contains the main body of the message
META_STORE - com.linkedin.venice.common.VeniceSystemStoreType
 
META_STORE_STR - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
META_STORE_WRITER_CLOSE_CONCURRENCY - Static variable in class com.linkedin.venice.ConfigKeys
A config to control the maximum number of concurrent meta store writer close operations.
META_STORE_WRITER_CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
A config to control the maximum time spent on closing the meta store writer.
META_SYSTEM_STORE_AUTO_CREATION_VALIDATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
metadata - Variable in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Metadata of the record; currently it contains the schemaId of the record
metadata - Variable in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
METADATA - com.linkedin.venice.meta.QueryAction
 
METADATA_PARTITION_ID - Static variable in class com.linkedin.davinci.store.AbstractStorageEngine
 
METADATA_RECORD_SUFFIX - Static variable in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
METADATA_SYSTEM_SCHEMA_STORE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Value schema for metadata system store.
METADATA_SYSTEM_SCHEMA_STORE_KEY - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Key schema for metadata system store.
MetadataFetchRequest - Class in com.linkedin.venice.listener.request
MetadataFetchRequest encapsulates a GET request to /metadata/storename on the storage node to fetch metadata for that node.
MetaDataHandler - Class in com.linkedin.venice.router
This MetaDataHandle is used to handle the following meta data requests: 1.
MetaDataHandler(HelixCustomizedViewOfflinePushRepository, ReadOnlySchemaRepository, ReadOnlyStoreConfigRepository, Map<String, String>, Map<String, String>, ReadOnlyStoreRepository, Optional<HelixHybridStoreQuotaRepository>, String, String, String, boolean, VeniceVersionFinder) - Constructor for class com.linkedin.venice.router.MetaDataHandler
 
MetadataRepoBasedTopicExistingCheckerImpl - Class in com.linkedin.davinci.kafka.consumer
 
MetadataRepoBasedTopicExistingCheckerImpl(ReadOnlyStoreRepository) - Constructor for class com.linkedin.davinci.kafka.consumer.MetadataRepoBasedTopicExistingCheckerImpl
 
metadataRepository - Variable in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
MetadataResponse - Class in com.linkedin.davinci.listener.response
This class stores all the information required for answering a server metadata fetch request.
MetadataResponse() - Constructor for class com.linkedin.davinci.listener.response.MetadataResponse
 
MetadataResponseRecord - Class in com.linkedin.venice.metadata.response
This record will store version properties, key & value schemas, and routing information
MetadataResponseRecord() - Constructor for class com.linkedin.venice.metadata.response.MetadataResponseRecord
Default constructor.
MetadataResponseRecord(VersionProperties, List<Integer>, Map<CharSequence, CharSequence>, Map<CharSequence, CharSequence>, Integer, Map<CharSequence, List<CharSequence>>, Map<CharSequence, Integer>, Integer) - Constructor for class com.linkedin.venice.metadata.response.MetadataResponseRecord
All-args constructor.
metadataSchema - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
MetadataSchemaCreation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
MetadataSchemaCreation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Default constructor.
MetadataSchemaCreation(CharSequence, CharSequence, Integer, SchemaMeta, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
All-args constructor.
metadataType - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
An integer (mapped to Enums) specifying the metadata type of the record.
metadataType - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
An integer (mapped to Enums) specifying the metadata type of the record.
metadataUnion - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
Contains different types of store metadata
MetadataUpdateStats - Class in com.linkedin.davinci.stats
MetadataUpdateStats records metrics related to storage metadata update via MainIngestionStorageMetadataService
MetadataUpdateStats(MetricsRepository) - Constructor for class com.linkedin.davinci.stats.MetadataUpdateStats
 
metadataUpdateType - Variable in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
0 => PutOffsetRecord, 1 => ClearOffsetRecord, 2 => PutStoreVersionState, 3 => ClearStoreVersionState
MetaStoreDataType - Enum in com.linkedin.venice.system.store
All the data types supported in meta system store.
MetaStoreReader - Class in com.linkedin.venice.system.store
 
MetaStoreReader(D2Client, String) - Constructor for class com.linkedin.venice.system.store.MetaStoreReader
 
MetaStoreShadowReader - Class in com.linkedin.venice.router.api
This class serves as the shadow read handler of the meta system store.
MetaStoreShadowReader(ReadOnlySchemaRepository) - Constructor for class com.linkedin.venice.router.api.MetaStoreShadowReader
 
metaStoreWriter - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
MetaStoreWriter - Class in com.linkedin.venice.system.store
This class is to write metadata: store properties/key schema/value schemas/replica statuses to meta system store.
MetaStoreWriter(TopicManager, VeniceWriterFactory, HelixReadOnlyZKSharedSchemaRepository, PubSubTopicRepository, long, int) - Constructor for class com.linkedin.venice.system.store.MetaStoreWriter
 
MetaSystemStoreAutoCreationValidation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
MetaSystemStoreAutoCreationValidation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
Default constructor.
MetaSystemStoreAutoCreationValidation(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
All-args constructor.
MeteredOutputStream - Class in com.linkedin.alpini.io
 
MeteredOutputStream(OutputStream) - Constructor for class com.linkedin.alpini.io.MeteredOutputStream
Creates an output stream filter built on top of the specified underlying output stream.
Method - Enum in com.linkedin.venice.authorization
Collection of all available methods that a Principal can perform.
METHOD_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
METHOD_GET - Static variable in class com.linkedin.venice.router.utils.VeniceRouterUtils
 
METHOD_POST - Static variable in class com.linkedin.venice.router.utils.VeniceRouterUtils
 
metric() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
METRIC - com.linkedin.venice.ingestion.protocol.enums.IngestionAction
 
METRIC_ONLY_AVAILABLE_FOR_HYBRID_STORES - com.linkedin.venice.stats.StatsErrorCode
Some metrics only make sense in the context of hybrid stores and should not be queried otherwise.
METRIC_ONLY_AVAILABLE_FOR_LEADER_FOLLOWER_STORES - com.linkedin.venice.stats.StatsErrorCode
Some metrics only make sense in the context of L/F stores and should not be queried otherwise.
metricChange(TehutiMetric) - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
MetricNames - Enum in com.linkedin.alpini.base.misc
 
Metrics - Class in com.linkedin.alpini.base.misc
 
Metrics() - Constructor for class com.linkedin.alpini.base.misc.Metrics
 
MetricsAware - Interface in com.linkedin.venice.tehuti
 
MetricsDecoder - Interface in com.linkedin.alpini.router.api
 
MetricsDecorator - Interface in com.linkedin.alpini.router.api
 
metricsProvider(BiFunction<Headers, Metrics, Headers>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
metricsProvider(Function<BasicRequest, Metrics>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
MetricsProvider - Interface in com.linkedin.alpini.router.api
 
metricsRepository - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
MetricsRepositoryUtils - Class in com.linkedin.venice.utils.metrics
Utility functions to help create common metrics repository.
MetricsRepositoryUtils() - Constructor for class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
 
MetricsUtils - Class in com.linkedin.venice.tehuti
Utility functions to help test metrics
MetricsUtils() - Constructor for class com.linkedin.venice.tehuti.MetricsUtils
 
MIGRATE_STORE - com.linkedin.venice.Command
 
MIGRATE_STORE - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
MIGRATE_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
migrateStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
migrateStore(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
migrateStore(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
migrateStore(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Main implementation for migrating a store from its source cluster to a new destination cluster.
migrateStore(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Migrate a store from its source cluster to a new destination cluster by sending a MIGRATE_STORE admin message.
MigrateStore - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
MigrateStore() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
Default constructor.
MigrateStore(CharSequence, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
All-args constructor.
migrating - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
migrating - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not the store is in the process of migration.
MIGRATION_DUPLICATE_STORE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
MIGRATION_PUSH_STRATEGY - com.linkedin.venice.Arg
 
MIGRATION_PUSH_STRATEGY_PATH - Static variable in class com.linkedin.venice.controller.migration.MigrationPushStrategyZKAccessor
 
MIGRATION_STATUS - com.linkedin.venice.Command
 
migrationDestCluster - Variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
The destination cluster for store migration
migrationDuplicateStore - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether or not the store is a duplicate store in the process of migration
migrationDuplicateStore - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not the store is a duplicate store in the process of migration.
MigrationPushStrategy - Enum in com.linkedin.venice.migration
 
MigrationPushStrategyJSONSerializer - Class in com.linkedin.venice.controller.migration
 
MigrationPushStrategyJSONSerializer() - Constructor for class com.linkedin.venice.controller.migration.MigrationPushStrategyJSONSerializer
 
MigrationPushStrategyResponse - Class in com.linkedin.venice.controllerapi
 
MigrationPushStrategyResponse() - Constructor for class com.linkedin.venice.controllerapi.MigrationPushStrategyResponse
 
MigrationPushStrategyZKAccessor - Class in com.linkedin.venice.controller.migration
 
MigrationPushStrategyZKAccessor(ZkClient, HelixAdapterSerializer) - Constructor for class com.linkedin.venice.controller.migration.MigrationPushStrategyZKAccessor
 
MigrationRoutes - Class in com.linkedin.venice.controller.server
 
MigrationRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.MigrationRoutes
 
migrationSrcCluster - Variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
The source cluster for store migration
milliseconds() - Method in class com.linkedin.venice.utils.TestMockTime
For interop with Tehuti's Time abstraction
MIN_ACTIVE_REPLICA - Static variable in class com.linkedin.venice.ConfigKeys
 
MIN_COMPACTION_LAG_SECONDS - com.linkedin.venice.Arg
 
MIN_COMPACTION_LAG_SECONDS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
MIN_CONSUMER_IN_CONSUMER_POOL_PER_KAFKA_CLUSTER - Static variable in class com.linkedin.venice.ConfigKeys
 
MIN_NUMBER_OF_STORE_VERSIONS_TO_PRESERVE - Static variable in class com.linkedin.venice.ConfigKeys
This is the number of fully-functional store-versions we wish to maintain.
MIN_NUMBER_OF_UNUSED_KAFKA_TOPICS_TO_PRESERVE - Static variable in class com.linkedin.venice.ConfigKeys
This is the minimum number of Kafka topics that are guaranteed to be preserved by the leaky topic clean up routine.
minAndMax() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
minCompactionLagSeconds - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Store-level version topic min compaction lag
minCompactionLagSeconds - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Store level min compaction lag config and if not specified, it will use the global config for version topics
MINIMUM_CONSUMER_NUM_IN_CONSUMER_POOL_PER_KAFKA_CLUSTER - Static variable in class com.linkedin.davinci.config.VeniceServerConfig
Since the RT topic could be consumed by multiple store versions for Hybrid stores, we couldn't share the consumer across different Hybrid store versions.
MINIMUM_IDLE_TIMEOUT_MILLIS - Static variable in interface com.linkedin.alpini.router.impl.Router.Builder
 
MINIMUM_MAX_CHUNK_SIZE - Static variable in interface com.linkedin.alpini.router.impl.Router.Builder
 
MINIMUM_MAX_CONTENT_LENGTH - Static variable in interface com.linkedin.alpini.router.impl.Router.Builder
 
MINIMUM_MAX_HEADER_SIZE - Static variable in interface com.linkedin.alpini.router.impl.Router.Builder
 
MINIMUM_MAX_INITIAL_LINE_LENGTH - Static variable in interface com.linkedin.alpini.router.impl.Router.Builder
 
MINIMUM_NUMBER_OF_SAMPLES_REQUIRED_TO_BUILD_ZSTD_DICTIONARY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Known zstd lib issue which crashes if the input sample is too small.
minInSyncReplicas() - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
minLogCompactionLagMs() - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
minSchemaCountToKeep - Variable in class com.linkedin.venice.controller.UnusedValueSchemaCleanupService
 
MINUTES_PER_HOUR - Static variable in interface com.linkedin.venice.utils.Time
 
minZeroLag(long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Because of timing considerations, it is possible that some lag metrics could compute negative values.
missCount() - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
missCount() - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns the approximate number of cache requests which were miss
MissingConfigParameterException(String) - Constructor for exception com.linkedin.venice.security.SSLConfig.ConfigHelper.MissingConfigParameterException
 
MissingDataException - Exception in com.linkedin.venice.exceptions.validation
This exception is thrown when we detect missing data in the Kafka stream.
MissingDataException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.MissingDataException
 
MissingDataException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.validation.MissingDataException
 
MissingKeyInStoreMetadataException - Exception in com.linkedin.venice.exceptions
 
MissingKeyInStoreMetadataException(String, String) - Constructor for exception com.linkedin.venice.exceptions.MissingKeyInStoreMetadataException
 
MissingKeyInStoreMetadataException(String, String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.MissingKeyInStoreMetadataException
 
MockCircularTime - Class in com.linkedin.venice.utils
A mock time that takes a list of synthetic timestamps in MS and return them one by one in a circular manner.
MockCircularTime(List<Long>) - Constructor for class com.linkedin.venice.utils.MockCircularTime
 
MockInMemoryAdminAdapter - Class in com.linkedin.venice.unit.kafka
 
MockInMemoryAdminAdapter(InMemoryKafkaBroker) - Constructor for class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
MockInMemoryConsumer - Class in com.linkedin.venice.unit.kafka.consumer
A PubSubConsumerAdapter implementation which reads messages from the InMemoryKafkaBroker.
MockInMemoryConsumer(InMemoryKafkaBroker, PollStrategy, PubSubConsumerAdapter) - Constructor for class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
MockInMemoryProducerAdapter - Class in com.linkedin.venice.unit.kafka.producer
A PubSubProducerAdapter implementation which interacts with the InMemoryKafkaBroker in order to make unit tests more lightweight.
MockInMemoryProducerAdapter(InMemoryKafkaBroker) - Constructor for class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
 
MockTehutiReporter - Class in com.linkedin.venice.tehuti
 
MockTehutiReporter() - Constructor for class com.linkedin.venice.tehuti.MockTehutiReporter
 
MockTestStateModelFactory - Class in com.linkedin.venice.utils
 
MockTestStateModelFactory(VeniceOfflinePushMonitorAccessor) - Constructor for class com.linkedin.venice.utils.MockTestStateModelFactory
 
MockTestStateModelFactory.OnlineOfflineStateModel - Class in com.linkedin.venice.utils
 
MockVeniceAuthorizer - Class in com.linkedin.venice.controller
A mock AuthorizerService implementation to help in unit test.
MockVeniceAuthorizer() - Constructor for class com.linkedin.venice.controller.MockVeniceAuthorizer
 
mode() - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
MODULE - Static variable in class com.linkedin.alpini.io.ExternalCommand
 
monitor(DataRecoveryClient.DataRecoveryParams, MonitorCommand.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
 
MONITOR_DATA_RECOVERY - com.linkedin.venice.Command
 
MonitorCommand - Class in com.linkedin.venice.datarecovery
 
MonitorCommand() - Constructor for class com.linkedin.venice.datarecovery.MonitorCommand
 
MonitorCommand(MonitorCommand.Params) - Constructor for class com.linkedin.venice.datarecovery.MonitorCommand
 
MonitorCommand.Params - Class in com.linkedin.venice.datarecovery
 
MonitorCommand.Params.Builder - Class in com.linkedin.venice.datarecovery
 
MonitorCommand.Result - Class in com.linkedin.venice.datarecovery
 
moveElement(int, int) - Method in class com.linkedin.davinci.utils.IndexedHashMap
O(N) in the worst case.
moveElement(int, int) - Method in interface com.linkedin.davinci.utils.IndexedMap
 
moveElement(int, int) - Method in interface com.linkedin.venice.utils.IndexedMap
 
MRJobCounterHelper - Class in com.linkedin.venice.hadoop.mapreduce.counter
All MapReducer job counters (identified by a group name + a counter name) are defined here and this util class provides method to increment counters and read counters
MRJobCounterHelper.GroupAndCounterNames - Class in com.linkedin.venice.hadoop.mapreduce.counter
Bundle counter group name and counter name in this POJO
MS_PER_DAY - Static variable in interface com.linkedin.venice.utils.Time
 
MS_PER_HOUR - Static variable in interface com.linkedin.venice.utils.Time
 
MS_PER_MINUTE - Static variable in interface com.linkedin.venice.utils.Time
 
MS_PER_SECOND - Static variable in interface com.linkedin.venice.utils.Time
 
Msg - Class in com.linkedin.alpini.base.misc
Message holder object for use with lazy logging.
MULTI_GET - com.linkedin.venice.read.RequestType
 
MULTI_GET_CLIENT_REQUEST_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Client request for multi-get v1.
MULTI_GET_RESPONSE_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Response record for multi-get v1.
MULTI_GET_ROUTER_REQUEST_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Router request key for multi-get v1.
MULTI_GET_STREAMING - com.linkedin.venice.read.RequestType
 
MULTI_GET_VALID_HEADER_MAP - Static variable in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
MULTI_REGION - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
This config specifies if Venice is deployed in a multi-region mode
multiClusterConfigs - Variable in class com.linkedin.venice.controller.kafka.TopicCleanupService
 
multiGet(int, List<byte[]>) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
multiGet(List<byte[]>) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
multiGet(List<byte[]>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
multiGet(List<ByteBuffer>, List<ByteBuffer>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
MultiGetRecordStreamDecoder<K,​V> - Class in com.linkedin.venice.client.store.streaming
 
MultiGetRecordStreamDecoder(List<K>, TrackingStreamingCallback<K, V>, Executor, RecordDeserializer<StreamingFooterRecordV1>, Function<Integer, RecordDeserializer<V>>, BiFunction<CompressionStrategy, ByteBuffer, ByteBuffer>) - Constructor for class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
 
multiGetReplicationMetadata(int, List<byte[]>) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
multiGetReplicationMetadata(List<byte[]>) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
multiGetReplicationMetadata(List<byte[]>) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
multiGetRequestSerializer - Variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
MultiGetResponseRecordV1 - Class in com.linkedin.venice.read.protocol.response
This field will store all the related info for one record
MultiGetResponseRecordV1() - Constructor for class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Default constructor.
MultiGetResponseRecordV1(Integer, ByteBuffer, Integer) - Constructor for class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
All-args constructor.
MultiGetResponseRecordV1ChunkedDeserializer - Class in com.linkedin.venice.client.store.streaming
 
MultiGetResponseRecordV1ChunkedDeserializer() - Constructor for class com.linkedin.venice.client.store.streaming.MultiGetResponseRecordV1ChunkedDeserializer
 
MultiGetResponseWrapper - Class in com.linkedin.venice.listener.response
 
MultiGetResponseWrapper(int) - Constructor for class com.linkedin.venice.listener.response.MultiGetResponseWrapper
 
MultiGetRouterRequestKeyV1 - Class in com.linkedin.venice.read.protocol.request.router
This field will store all the related info for one key
MultiGetRouterRequestKeyV1() - Constructor for class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Default constructor.
MultiGetRouterRequestKeyV1(Integer, ByteBuffer, Integer) - Constructor for class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
All-args constructor.
MultiGetRouterRequestWrapper - Class in com.linkedin.venice.listener.request
MultiGetRouterRequestWrapper encapsulates a POST request to storage/resourcename on the storage node for a multi-get operation.
MultiKeyRequestContext<K,​V> - Class in com.linkedin.venice.fastclient
Keep track of the progress of a multi-key requests - batch get and compute.
MultiKeyRequestContext.KeyInfo<K> - Class in com.linkedin.venice.fastclient
represents a key requested on a route and tracks info related to it but specific to the route
MultiKeyResponseWrapper<K> - Class in com.linkedin.venice.listener.response
 
MultiKeyResponseWrapper(int) - Constructor for class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
 
MultiKeyRouterRequestWrapper<K> - Class in com.linkedin.venice.listener.request
MultiKeyRouterRequestWrapper is a base class for a multi-key operation.
MultiKeyRouterRequestWrapper(String, List<K>, boolean, boolean) - Constructor for class com.linkedin.venice.listener.request.MultiKeyRouterRequestWrapper
 
MultiKeyRouterRequestWrapper(String, List<K>, HttpRequest) - Constructor for class com.linkedin.venice.listener.request.MultiKeyRouterRequestWrapper
 
MultiNodeResponse - Class in com.linkedin.venice.controllerapi
 
MultiNodeResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiNodeResponse
 
MultiNodesStatusResponse - Class in com.linkedin.venice.controllerapi
 
MultiNodesStatusResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiNodesStatusResponse
 
MULTIPART_LOG - Static variable in interface com.linkedin.alpini.netty4.misc.HttpMultiPart
 
MultipartContent - Interface in com.linkedin.alpini.netty4.misc
 
MultipartHttpResponse - Interface in com.linkedin.alpini.netty4.misc
 
multiRegion - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
MultiReplicaResponse - Class in com.linkedin.venice.controllerapi
 
MultiReplicaResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiReplicaResponse
 
MultiSchemaIdResponse - Class in com.linkedin.venice.controllerapi
 
MultiSchemaIdResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiSchemaIdResponse
 
MultiSchemaResponse - Class in com.linkedin.venice.controllerapi
 
MultiSchemaResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiSchemaResponse
 
MultiSchemaResponse.Schema - Class in com.linkedin.venice.controllerapi
 
multiStatus() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
multiStatus() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
MultiStoragePersonaResponse - Class in com.linkedin.venice.controllerapi
 
MultiStoragePersonaResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiStoragePersonaResponse
 
MultiStoreInfoResponse - Class in com.linkedin.venice.controllerapi
 
MultiStoreInfoResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiStoreInfoResponse
 
MultiStoreResponse - Class in com.linkedin.venice.controllerapi
 
MultiStoreResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiStoreResponse
 
MultiStoreStatusResponse - Class in com.linkedin.venice.controllerapi
 
MultiStoreStatusResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiStoreStatusResponse
 
MultiStoreTopicsResponse - Class in com.linkedin.venice.controllerapi
 
MultiStoreTopicsResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiStoreTopicsResponse
 
MultiVersionResponse - Class in com.linkedin.venice.controllerapi
Created by mwise on 5/3/16.
MultiVersionResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiVersionResponse
 
MultiVersionStatusResponse - Class in com.linkedin.venice.controllerapi
 
MultiVersionStatusResponse() - Constructor for class com.linkedin.venice.controllerapi.MultiVersionStatusResponse
 
MutablePubSubMessage() - Constructor for class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
mutableSetOf(T...) - Static method in class com.linkedin.venice.utils.Utils
 

N

name - Variable in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
name - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
name - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
name - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
name - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
name - Variable in enum com.linkedin.venice.schema.writecompute.WriteComputeOperation
 
name - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Store name.
name() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolWithStats
 
name() - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
name() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
name() - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
name() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
name() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputTable
 
name(String) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
name(String) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
NAME - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
NAME_RECORD_V1_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
NAME_RECORD_V1_UPDATE_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
NAME_RECORD_V2_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
NAME_RECORD_V3_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
NAME_RECORD_V4_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
NAME_SPACE - Static variable in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
NamedThreadFactory - Class in com.linkedin.alpini.base.concurrency
ThreadFactory which creates named threads for use in an ExecutorService.
NamedThreadFactory - Class in com.linkedin.venice.utils
A thread factory that sets the threads to create threads with a specific prefix name.
NamedThreadFactory() - Constructor for class com.linkedin.venice.utils.NamedThreadFactory
This constructor is used when the thread name is unknown (or do not need to be set at construct time)
NamedThreadFactory(String) - Constructor for class com.linkedin.alpini.base.concurrency.NamedThreadFactory
Construct a new NamedThreadFactory with the given pool name.
NamedThreadFactory(String) - Constructor for class com.linkedin.venice.utils.NamedThreadFactory
 
NamedThreadFactory(String, Runnable) - Constructor for class com.linkedin.venice.utils.NamedThreadFactory
 
NamedThreadFactory(ThreadGroup, String) - Constructor for class com.linkedin.alpini.base.concurrency.NamedThreadFactory
Construct a new NamedThreadFactory with the given thread group and pool name.
NamedThreadFactory(ThreadFactory, String) - Constructor for class com.linkedin.alpini.base.concurrency.NamedThreadFactory
 
names() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
nameUUIDFromBytes(byte[]) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Static factory to retrieve a type 4 (pseudo-random) UUID based on the specified byte array after transformation with the Jenkins hash function.
nanoseconds() - Method in class com.linkedin.venice.utils.TestMockTime
For interop with Tehuti's Time abstraction
nanoTime() - Static method in enum com.linkedin.alpini.base.misc.Time
 
nanoToMillis(double) - Static method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
NATIVE_REPLICATION_DEFAULT_SOURCE_FABRIC - Static variable in class com.linkedin.venice.VeniceConstants
 
NATIVE_REPLICATION_ENABLED - com.linkedin.venice.Arg
 
NATIVE_REPLICATION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
NATIVE_REPLICATION_FABRIC_ALLOWLIST - Static variable in class com.linkedin.venice.ConfigKeys
Previously ConfigKeys.CHILD_CLUSTER_ALLOWLIST is used to also represent the allowlist of source fabrics for native replication; however, the final migration plan decides that a Kafka cluster in parent fabric can also be the source fabric, so the below config is introduced to represent all potential source fabrics for native replication.
NATIVE_REPLICATION_FABRIC_WHITELIST - Static variable in class com.linkedin.venice.ConfigKeys
Deprecated.
NATIVE_REPLICATION_SOURCE_FABRIC - com.linkedin.venice.Arg
 
NATIVE_REPLICATION_SOURCE_FABRIC - Static variable in class com.linkedin.venice.ConfigKeys
The default source fabric used for native replication
NATIVE_REPLICATION_SOURCE_FABRIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
NATIVE_REPLICATION_SOURCE_FABRIC_AS_DEFAULT_FOR_BATCH_ONLY_STORES - Static variable in class com.linkedin.venice.ConfigKeys
The default source fabric used for native replication for batch only stores.
NATIVE_REPLICATION_SOURCE_FABRIC_AS_DEFAULT_FOR_HYBRID_STORES - Static variable in class com.linkedin.venice.ConfigKeys
The default source fabric used for native replication for hybrid stores.
NativeMetadataRepository - Class in com.linkedin.davinci.repository
Venice in-house implementation of a read only metadata repository where callers can retrieve various metadata such as Store objects and their corresponding schemas.
NativeMetadataRepository(ClientConfig, VeniceProperties) - Constructor for class com.linkedin.davinci.repository.NativeMetadataRepository
 
nativeReplicationEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
nativeReplicationEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
nativeReplicationEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
nativeReplicationEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not native should be enabled for this store.
nativeReplicationEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Whether or not native replication is enabled.
nativeReplicationSourceFabric - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
The source fabric to be used when the store is running in Native Replication mode.
nativeReplicationSourceFabric - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
The source fabric name to be uses in native replication.
nativeReplicationSourceFabric - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
The source fabric name to be uses in native replication.
nativeReplicationSourceRegion - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
The source region to be used when the store is running in Native Replication mode.
NEARLINE - com.linkedin.venice.utils.TestWriteUtils.TestRecordType
 
NEARLINE_LOCAL_BROKER_TO_READY_TO_SERVE_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
NEARLINE_PRODUCER_TO_LOCAL_BROKER_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
needSchemaReader - Variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
needWaitForFirstTaskToComplete() - Method in class com.linkedin.venice.datarecovery.Command
 
needWaitForFirstTaskToComplete() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
For some task, it is benefit to wait for the first task to complete before starting to run the remaining ones.
needWaitForFirstTaskToComplete() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
needWaitForFirstTaskToComplete() - Method in class com.linkedin.venice.datarecovery.MonitorCommand
 
needWaitForFirstTaskToComplete() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
needWaitForFirstTaskToComplete(DataRecoveryTask) - Method in class com.linkedin.venice.datarecovery.DataRecoveryWorker
For some task, it is benefit to wait for the first task to complete before starting to run the remaining ones.
Netty - Enum in com.linkedin.alpini.router.api
 
NETTY_3 - com.linkedin.alpini.router.api.Netty
 
NETTY_4_1 - com.linkedin.alpini.router.api.Netty
 
Netty4RouterException - Exception in com.linkedin.alpini.router.api
 
Netty4RouterException(HttpResponseStatus, boolean) - Constructor for exception com.linkedin.alpini.router.api.Netty4RouterException
 
Netty4RouterException(HttpResponseStatus, boolean, Throwable) - Constructor for exception com.linkedin.alpini.router.api.Netty4RouterException
 
Netty4RouterException(HttpResponseStatus, boolean, Throwable, boolean, boolean) - Constructor for exception com.linkedin.alpini.router.api.Netty4RouterException
 
Netty4RouterException(HttpResponseStatus, String, boolean) - Constructor for exception com.linkedin.alpini.router.api.Netty4RouterException
 
Netty4RouterException(HttpResponseStatus, String, boolean, Throwable) - Constructor for exception com.linkedin.alpini.router.api.Netty4RouterException
 
Netty4RouterException(HttpResponseStatus, String, boolean, Throwable, boolean, boolean) - Constructor for exception com.linkedin.alpini.router.api.Netty4RouterException
 
Netty4ThrowException - Class in com.linkedin.alpini.base.misc
Simple wrapper using Netty4 PlatformDependent implementation
Netty4ThrowException() - Constructor for class com.linkedin.alpini.base.misc.Netty4ThrowException
 
NettyChunkedWriteHandler - Class in com.linkedin.venice.router.streaming
This class was copied from ChunkedWriteHandler, and the only change we made here is to using ConcurrentLinkedQueue for NettyChunkedWriteHandler.queue since NettyChunkedWriteHandler.resumeTransfer() or NettyChunkedWriteHandler.discard(Throwable) could happen in any sequence with any parallelism because of scatter/gather logic in Venice Router.
NettyChunkedWriteHandler() - Constructor for class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
 
NettyChunkedWriteHandler(int) - Constructor for class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
NettyUtils - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/30/17.
NettyUtils - Class in com.linkedin.venice.utils
 
NettyUtils() - Constructor for class com.linkedin.venice.utils.NettyUtils
 
NettyUtils.Mode - Enum in com.linkedin.alpini.netty4.misc
 
NettyUtils.ReadMode - Enum in com.linkedin.alpini.netty4.misc
 
nettyVersion() - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
nettyVersion() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
nettyVersion() - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
nettyVersion() - Method in interface com.linkedin.alpini.router.impl.Router
 
NettyVersion - Annotation Type in com.linkedin.alpini.router.api
 
NEW - com.linkedin.venice.pushmonitor.ExecutionStatus
Legacy status.
NEW_LINE_CHAR - Static variable in class com.linkedin.venice.utils.Utils
 
NEW_STORAGE_PERSONA - com.linkedin.venice.Command
 
NEW_STORE - com.linkedin.venice.Command
 
NEW_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
NEW_STORE_ACL - com.linkedin.venice.Command
 
NEW_VERSION_CREATED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
newArray(Object, int, Schema) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
The reason to override this function is that VSON would like to use ArrayList instead of GenericData.Array to support comparison against another AbstractList.
newBlockingStub(Channel) - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
Creates a new blocking-style stub that supports unary and streaming output calls on the service
newBuilder() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
newBuilder() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
newBuilder(VeniceClientRequest) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
newBuilder(VeniceServerResponse) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
newBuilderForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
newBuilderForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
newBuilderForType(GeneratedMessageV3.BuilderParent) - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
newCachedThreadPool() - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a thread pool that creates new threads as needed, but will reuse previously constructed threads when they are available.
newCachedThreadPool() - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a thread pool that creates new threads as needed, but will reuse previously constructed threads when they are available.
newCachedThreadPool(ThreadFactory) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a thread pool that creates new threads as needed, but will reuse previously constructed threads when they are available, and uses the provided ThreadFactory to create new threads when needed.
newCachedThreadPool(ThreadFactory) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a thread pool that creates new threads as needed, but will reuse previously constructed threads when they are available, and uses the provided ThreadFactory to create new threads when needed.
newChild(Executor, Object...) - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
newChild(Executor, Object...) - Method in class com.linkedin.alpini.netty4.misc.SingleThreadEventLoopGroup
 
newChooser(EventExecutor[]) - Method in class com.linkedin.alpini.netty4.misc.RandomEventExecutorChooserFactory
 
newChooser(EventExecutor[]) - Method in class com.linkedin.alpini.netty4.misc.StickyEventExecutorChooserFactory
 
newChunkDeleteRecord(byte[], Delete) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
newChunkPutRecord(byte[], Put) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
NewClusterBuildOutRoutes - Class in com.linkedin.venice.controller.server
 
NewClusterBuildOutRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.NewClusterBuildOutRoutes
 
newCompletion() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
newContentDecoder(String) - Method in class com.linkedin.alpini.netty4.compression.ContentDecompressor
 
newContinueResponse(HttpMessage, int, ChannelPipeline) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpObjectAggregator
 
newContinueResponse(HttpMessage, int, ChannelPipeline) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentAggregator
 
newContinueResponse(HttpMessage, int, ChannelPipeline) - Method in class io.netty.handler.codec.http.EspressoHttpObjectAggregator
 
newContinueResponse(S, int, ChannelPipeline) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Returns the 'continue response' for the specified start message if necessary.
newControlMessageRecord(byte[], ControlMessage) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
newControlMessageRecord(int, long, byte[], ControlMessage) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
newData() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
newData() - Method in class com.linkedin.alpini.base.statistics.LongStatsAggregator
 
newDeleteRecord(int, long, byte[], Delete) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
newDirectBuffer(int, int) - Method in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
newEventLoopGroup(int, Executor) - Method in enum com.linkedin.alpini.netty4.misc.NettyUtils.Mode
 
newEventLoopGroup(int, Executor) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
newEventLoopGroup(int, ThreadFactory) - Method in enum com.linkedin.alpini.netty4.misc.NettyUtils.Mode
 
newEventLoopGroup(int, ThreadFactory) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
newExceptionForStore(String) - Static method in exception com.linkedin.venice.exceptions.StoreKeySchemaExistException
 
newFixedThreadPool(int) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a thread pool that reuses a fixed number of threads operating off a shared unbounded queue.
newFixedThreadPool(int) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a thread pool that reuses a fixed number of threads operating off a shared unbounded queue.
newFixedThreadPool(int, ThreadFactory) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a thread pool that reuses a fixed number of threads operating off a shared unbounded queue, using the provided ThreadFactory to create new threads when needed.
newFixedThreadPool(int, ThreadFactory) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a thread pool that reuses a fixed number of threads operating off a shared unbounded queue, using the provided ThreadFactory to create new threads when needed.
newFullMessage(int, Http2Headers, boolean, ByteBufAllocator) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
newFullMessage(int, Http2Headers, boolean, ByteBufAllocator) - Method in class com.linkedin.alpini.netty4.http2.Http2StreamFrameClientCodec
 
newFullMessage(int, Http2Headers, boolean, ByteBufAllocator) - Method in class com.linkedin.alpini.netty4.http2.Http2StreamFrameServerCodec
 
newFutureStub(Channel) - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
Creates a new ListenableFuture-style stub that supports unary calls on the service
newHeapBuffer(int, int) - Method in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
newInstance(GeneratedMessageV3.UnusedPrivateParameter) - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
newMap(Object, int) - Method in class com.linkedin.davinci.serializer.avro.MapOrderPreservingDatumReader
 
newMap(Object, int) - Method in class com.linkedin.venice.serialization.avro.VeniceSpecificDatumReader
Called to create new array instances.
newMessage(int, Http2Headers, boolean) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
newMessage(int, Http2Headers, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http2StreamFrameClientCodec
 
newMessage(int, Http2Headers, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http2StreamFrameServerCodec
 
newParams() - Method in class com.linkedin.venice.controllerapi.ControllerClient
Add all global parameters in this method.
newPoolChannelGroup() - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
newPoolChannelGroup() - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
newPutRecord(int, long, byte[], Put) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
newPutRecordWithFuture(int, long, byte[], Put, CompletableFuture<Void>) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
newQOSBasedQueue() - Method in class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
Creates a QOS based queue for a ring element.
newQueue() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
Create a new single-producer multiple-consumer thread-safe queue
newReference(T, Runnable) - Static method in class com.linkedin.alpini.base.misc.LeakDetect
Make a phantom reference for leak detection.
newRouterExceptionAndTracking(Optional<String>, Optional<RequestType>, HttpResponseStatus, String) - Static method in class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
 
newRouterExceptionAndTracking(Optional<String>, Optional<RequestType>, HttpResponseStatus, String, RouterExceptionAndTrackingUtils.FailureType) - Static method in class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
 
newRouterExceptionAndTrackingResourceNotFound(Optional<String>, Optional<RequestType>, HttpResponseStatus, String) - Static method in class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
 
newSample(T) - Method in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation
 
newScanBuilder(CaseInsensitiveStringMap) - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputTable
 
newScheduledThreadPool(int) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a thread pool that can schedule commands to run after a given delay, or to execute periodically.
newScheduledThreadPool(int) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a thread pool that can schedule commands to run after a given delay, or to execute periodically.
newScheduledThreadPool(int, ThreadFactory) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a thread pool that can schedule commands to run after a given delay, or to execute periodically.
newScheduledThreadPool(int, ThreadFactory) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a thread pool that can schedule commands to run after a given delay, or to execute periodically.
newServingVersionTopic - Variable in class com.linkedin.venice.kafka.protocol.VersionSwap
Name of the new source topic we are switching to.
newSet(ComplementSet<T>) - Static method in class com.linkedin.venice.utils.ComplementSet
 
newSet(Collection<T>) - Static method in class com.linkedin.venice.utils.ComplementSet
This API will result in copying the data set, which is not performant or GC friendly if it's in critical path.
newSingleThreadExecutor() - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates an Executor that uses a single worker thread operating off an unbounded queue.
newSingleThreadExecutor() - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates an Executor that uses a single worker thread operating off an unbounded queue.
newSingleThreadExecutor(ThreadFactory) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates an Executor that uses a single worker thread operating off an unbounded queue, and uses the provided ThreadFactory to create a new thread when needed.
newSingleThreadExecutor(ThreadFactory) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates an Executor that uses a single worker thread operating off an unbounded queue, and uses the provided ThreadFactory to create a new thread when needed.
newSingleThreadScheduledExecutor() - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a single-threaded executor that can schedule commands to run after a given delay, or to execute periodically.
newSingleThreadScheduledExecutor() - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a single-threaded executor that can schedule commands to run after a given delay, or to execute periodically.
newSingleThreadScheduledExecutor(ThreadFactory) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Creates a single-threaded executor that can schedule commands to run after a given delay, or to execute periodically.
newSingleThreadScheduledExecutor(ThreadFactory) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
Creates a single-threaded executor that can schedule commands to run after a given delay, or to execute periodically.
newSnappyDecoder() - Static method in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
newSnappyFramedDecoder() - Static method in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
newSortedSet(Comparator<LongQuantileEstimation.Sample>) - Method in class com.linkedin.alpini.base.statistics.LongQuantileArrayEstimation
 
newSortedSet(Comparator<LongQuantileEstimation.Sample>) - Method in class com.linkedin.alpini.base.statistics.LongStatsArrayAggregator
 
newSortedSet(Comparator<SAMPLE>) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
NewStoreResponse - Class in com.linkedin.venice.controllerapi
 
NewStoreResponse() - Constructor for class com.linkedin.venice.controllerapi.NewStoreResponse
 
newStream(Http2FrameCodec) - Static method in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecUtil
Calls frameCodec.newStream() and returns the result
newStub(Channel) - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
Creates a new async stub that supports all call types for the service
newTaskFor(Runnable, T) - Method in class com.linkedin.alpini.base.misc.ThreadPoolExecutor
Returns a RunnableFuture for the given runnable and default value.
newTaskFor(Callable<T>) - Method in class com.linkedin.alpini.base.misc.ThreadPoolExecutor
Returns a RunnableFuture for the given callable task.
newThread(Runnable) - Method in class com.linkedin.alpini.base.concurrency.NamedThreadFactory
Create a new Thread for the specified Runnable.
newThread(Runnable) - Method in class com.linkedin.venice.utils.DaemonThreadFactory
 
newThread(Runnable) - Method in class com.linkedin.venice.utils.NamedThreadFactory
 
newThreadWithName(Runnable, String) - Method in class com.linkedin.venice.utils.NamedThreadFactory
 
newVeniceExceptionAndTracking(Optional<String>, Optional<RequestType>, HttpResponseStatus, String) - Static method in class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
Deprecated.
newVeniceExceptionAndTracking(Optional<String>, Optional<RequestType>, HttpResponseStatus, String, RouterExceptionAndTrackingUtils.FailureType) - Static method in class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
Deprecated.
newZkClient(String) - Static method in class com.linkedin.venice.helix.ZkClientFactory
 
next - Variable in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
 
next() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
next() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
next() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
 
next() - Method in interface com.linkedin.venice.hadoop.input.recordreader.VeniceRecordIterator
Proceed to next record, returns false if there is no more records.
next() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
 
next() - Method in class com.linkedin.venice.hadoop.spark.input.VeniceAbstractPartitionReader
 
next(KafkaInputMapperKey, KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
This function will skip all the Control Messages right now.
nextSeqNum() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Apply an unique and increasing sequence number for each consumer action, so if there are multiple consumer actions in the queue and they have the same priority, whichever be added first into the queue will be polled out first from the queue (FIFO).
NIO - com.linkedin.alpini.netty4.misc.NettyUtils.Mode
 
NO_CURRENT_VERSION - com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
 
NO_GCM_CIPHERS - Static variable in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
Similiar ciphers as WITH_GCM_CIPHERS except with CBC substituted instead of GCM because GCM is crushingly slow in current Java implementations.
NO_OP - com.linkedin.venice.compression.CompressionStrategy
 
NO_OP - com.linkedin.venice.samza.SamzaExitMode
Do nothing; this mode is mostly used in test cases.
NO_OP_COMPRESSOR - Static variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
NO_OP_ON_FIELD - com.linkedin.venice.schema.writecompute.WriteComputeOperation
Mark to ignore the field.
NO_PROGRESS - Static variable in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
NO_REQUEST_TIMEOUT - Static variable in class com.linkedin.venice.listener.request.RouterRequest
 
NO_SSL_HANDSHAKE - Static variable in class com.linkedin.alpini.netty4.ssl.SslInitializer
 
NO_SUBSCRIBED_PARTITION - com.linkedin.venice.stats.StatsErrorCode
Some metrics aggregate data across many partitions.
NODE_REMOVABLE - com.linkedin.venice.Command
 
NODE_REMOVABLE - com.linkedin.venice.controllerapi.ControllerRoute
 
NODE_REPLICAS - com.linkedin.venice.controllerapi.ControllerRoute
 
NODE_REPLICAS_READINESS - com.linkedin.venice.controllerapi.ControllerRoute
 
NodeRemovableResult - Class in com.linkedin.venice.controller
 
NodeRemovableResult.BlockingRemoveReason - Enum in com.linkedin.venice.controller
 
nodeReplicaReadiness(String, String) - Method in interface com.linkedin.venice.controller.Admin
helixNodeId nodeId of helix participant.
nodeReplicaReadiness(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
nodeReplicaReadiness(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
nodeReplicasReadiness(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
No ACL check; any user is allowed to check replicas readiness.
nodeReplicasReadiness(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
NodeReplicasReadinessResponse - Class in com.linkedin.venice.controllerapi
 
NodeReplicasReadinessResponse() - Constructor for class com.linkedin.venice.controllerapi.NodeReplicasReadinessResponse
 
NodeReplicasReadinessState - Enum in com.linkedin.venice.controllerapi
 
NodesAndReplicas - Class in com.linkedin.venice.controller.server
 
NodesAndReplicas(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.NodesAndReplicas
TODO: Make sure services "venice-hooks-deployable" is also in allowlist
NodeStatusResponse - Class in com.linkedin.venice.controllerapi
Response to represent the status of a node
NodeStatusResponse() - Constructor for class com.linkedin.venice.controllerapi.NodeStatusResponse
 
NON_AA_REPLICATION_UPSTREAM_OFFSET_MAP_KEY - Static variable in class com.linkedin.venice.offsets.OffsetRecord
 
NON_AGGREGATE - com.linkedin.venice.meta.DataReplicationPolicy
Default value.
NON_CHUNK_KEY_SUFFIX - Static variable in class com.linkedin.venice.serialization.KeyWithChunkingSuffixSerializer
 
NON_CRITICAL_EXCEPTION - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
NON_EXISTING_KEY_SCHEMA_ID - Static variable in class com.linkedin.venice.streaming.StreamingConstants
 
NON_EXISTING_VERSION - Static variable in interface com.linkedin.venice.meta.Store
Special version number indicates none of version is available to read.
NON_INTERACTIVE - com.linkedin.venice.Arg
 
NONE - com.linkedin.venice.etl.ETLValueSchemaTransformation
 
NONE - com.linkedin.venice.kafka.validation.checksum.CheckSumType
 
NONE - com.linkedin.venice.meta.DataReplicationPolicy
This enum value is used in 2 cases: 1.
NONE - com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
Anything goes.
NonEmptyStringMatcher - Class in com.linkedin.venice.unit.matchers
 
NonEmptyStringMatcher() - Constructor for class com.linkedin.venice.unit.matchers.NonEmptyStringMatcher
 
NonLocalAccessException - Exception in com.linkedin.davinci.client
 
NonLocalAccessException() - Constructor for exception com.linkedin.davinci.client.NonLocalAccessException
 
NonLocalAccessException(String) - Constructor for exception com.linkedin.davinci.client.NonLocalAccessException
 
NonLocalAccessException(String, int) - Constructor for exception com.linkedin.davinci.client.NonLocalAccessException
 
NonLocalAccessException(String, Throwable) - Constructor for exception com.linkedin.davinci.client.NonLocalAccessException
 
NonLocalAccessException(Throwable) - Constructor for exception com.linkedin.davinci.client.NonLocalAccessException
 
nonNullSize() - Method in class com.linkedin.venice.utils.SparseConcurrentList
N.B.: The intent of having a separate function for this, and to not override the behavior of CopyOnWriteArrayList.size() is that if the code does a for loop using the size, we want them to be able to get every element, e.g.: for (int i = 0; i < list.size(); i++) { doSomething(list.get(i)); } An alternative is to call SparseConcurrentList.values() which filters out nulls, e.g.: for (E element: list.values()) { doSomething(element); }
nonRemovableResult(String, NodeRemovableResult.BlockingRemoveReason, String) - Static method in class com.linkedin.venice.controller.NodeRemovableResult
 
NoopCompressor - Class in com.linkedin.venice.compression
 
NoopCompressor() - Constructor for class com.linkedin.venice.compression.NoopCompressor
 
NoOpPushJobHeartbeatSender - Class in com.linkedin.venice.hadoop.heartbeat
 
NoOpPushJobHeartbeatSender() - Constructor for class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSender
 
NoOpPushJobHeartbeatSenderFactory - Class in com.linkedin.venice.hadoop.heartbeat
 
NoOpPushJobHeartbeatSenderFactory() - Constructor for class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSenderFactory
 
NoOpSentPushJobDetailsTracker - Class in com.linkedin.venice.hadoop
 
NoOpSentPushJobDetailsTracker() - Constructor for class com.linkedin.venice.hadoop.NoOpSentPushJobDetailsTracker
 
NoOpValidator - Class in com.linkedin.venice.hadoop.validation
No Op validator.
NoOpValidator() - Constructor for class com.linkedin.venice.hadoop.validation.NoOpValidator
 
NOP - Static variable in class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
NORMAL - com.linkedin.alpini.consts.QOS
 
NOT_CREATED - com.linkedin.venice.meta.VersionStatus
 
NOT_CREATED - com.linkedin.venice.pushmonitor.ExecutionStatus
Job doesn't yet exist
NOT_CREATED - com.linkedin.venice.status.PushJobDetailsStatus
 
NOT_ENOUGH_BYTES_EXCEPTION - Static variable in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
 
NOT_EXIST - com.linkedin.davinci.ingestion.main.MainPartitionIngestionStatus
 
NOT_IMPLEMENTED_MSG - Static variable in class com.linkedin.venice.controller.server.NotImplemented
 
NOT_SENT - com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
 
NOT_SET - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
NOT_STARTED - com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
 
NOT_STARTED - com.linkedin.venice.hadoop.jobs.ComputeJob.Status
A job that has not started execution yet
NOT_STARTED - com.linkedin.venice.kafka.validation.SegmentStatus
NOT_STARTED - com.linkedin.venice.pushmonitor.ExecutionStatus
Job/Task is created but ingestion haven't started yet
NOT_SUPPORTED - com.linkedin.venice.stats.StatsErrorCode
 
NOT_UPDATED_AT_ALL - com.linkedin.davinci.schema.merge.UpdateResultStatus
 
NotEnoughBytesException() - Constructor for exception com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer.NotEnoughBytesException
 
notifyFlushToDisk(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
notifyGrowFailure(SocketAddress, Throwable) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
notifyGrowFailure(SocketAddress, Throwable) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
notifyOfTopicDeletion(String) - Method in interface com.linkedin.davinci.ingestion.consumption.ConsumedDataReceiver
 
notifyOfTopicDeletion(String) - Method in class com.linkedin.davinci.kafka.consumer.StorePartitionDataReceiver
 
notifyShutdown() - Method in class com.linkedin.venice.d2.D2Server
 
notifyStartup() - Method in class com.linkedin.venice.d2.D2Server
 
notifyStoreChanged(Store) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
notifyStoreChanged(Store) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
notifyStoreCreated(Store) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
notifyStoreCreated(Store) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
notifyStoreDeleted(Store) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
notifyStoreDeleted(Store) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
NotImplemented - Class in com.linkedin.venice.controller.server
 
NotImplemented() - Constructor for class com.linkedin.venice.controller.server.NotImplemented
 
notLessThan(int, int, String) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
notLessThan(long, long, String) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
NotThreadsafe - Annotation Type in com.linkedin.venice.annotation
Warns that a class is not threadsafe.
NS_PER_MS - Static variable in interface com.linkedin.venice.utils.Time
 
NS_PER_SECOND - Static variable in interface com.linkedin.venice.utils.Time
 
NS_PER_US - Static variable in interface com.linkedin.venice.utils.Time
 
NULL_BDB_ENVIRONMENT - com.linkedin.venice.stats.StatsErrorCode
The BDB stats depend on getting a handle of com.sleepycat.je.Environment.
NULL_BDB_STATS - com.linkedin.venice.stats.StatsErrorCode
Since storage engine stats has been migrated to versioned stats.
NULL_DIV_STATS - com.linkedin.venice.stats.StatsErrorCode
When the DIVStatsReporter attempts to get stats, it tries to get hold of an instance of DIVStats which should have been set previously.
NULL_INGESTION_STATS - com.linkedin.venice.stats.StatsErrorCode
Used by AggVersionedStorageIngestionStats when the stats reporter fetches a null stats.
NULL_STORAGE_ENGINE_STATS - com.linkedin.venice.stats.StatsErrorCode
Check AggVersionedStorageEngineStats to find more details.
NULL_SUCCESS - Static variable in interface com.linkedin.alpini.base.concurrency.AsyncFuture
 
nullableUnion(Schema) - Static method in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
Deprecated.
Wrap a schema with a union so that it could return null if necessary From Vson's point of view, all fields can be optional (null is allowed to be return).
NullCallTracker - Class in com.linkedin.alpini.base.monitoring
Created by acurtis on 3/30/17.
NullCallTracker() - Constructor for class com.linkedin.alpini.base.monitoring.NullCallTracker
 
NullOutputStream - Class in com.linkedin.alpini.io
A simple @{link OutputStream} implementation which is equivalent to /dev/null by acting as a sink for bytes.
NullOutputStream() - Constructor for class com.linkedin.alpini.io.NullOutputStream
 
NullSkippingIteratorWrapper<E> - Class in com.linkedin.venice.utils.collections
This iterator traverses the entire backing iterator, while skipping over null entries.
NullSkippingIteratorWrapper(Iterator<E>) - Constructor for class com.linkedin.venice.utils.collections.NullSkippingIteratorWrapper
 
NullStats - Class in com.linkedin.alpini.base.pool.impl
 
nullTracker() - Static method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
NUM_VERSION_PRESERVE_NOT_SET - Static variable in interface com.linkedin.venice.meta.Store
Default value of numVersionPreserve, by default we should use cluster level config instead of store level config.
NUM_VERSIONS_TO_PRESERVE - com.linkedin.venice.Arg
 
NUM_VERSIONS_TO_PRESERVE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
number - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Version number.
numberBasedDummyPushId(int) - Static method in interface com.linkedin.venice.meta.Version
 
numberOfPartitions - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
numPartitions() - Method in class com.linkedin.venice.hadoop.spark.datawriter.partition.VeniceSparkPartitioner
 
numVersionsToPreserve - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
The max number of versions the store should preserve.
numVersionsToPreserve - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
numVersionsToPreserve - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
How many versions this store preserve at most.

O

OBJECT_MAPPER - Static variable in class com.linkedin.venice.controller.server.AdminSparkServer
 
OBJECT_MAPPER - Static variable in class com.linkedin.venice.helix.VeniceJsonSerializer
 
ObjectCacheBackend - Class in com.linkedin.davinci.store.cache.backend
This class is in charge of managing access and maintenance of a VeniceStoreCache.
ObjectCacheBackend(ClientConfig, ObjectCacheConfig, ReadOnlySchemaRepository) - Constructor for class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
ObjectCacheConfig - Class in com.linkedin.davinci.store.cache.backend
 
ObjectCacheConfig() - Constructor for class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
ObjectMapperFactory - Class in com.linkedin.venice.utils
 
ObjectPool<O> - Interface in com.linkedin.venice.utils.pools
An interface to get and give back objects that are intended to be long-lived and recycled, but where the location in the code for beginning to use the object is far from the location where we stop using it, e.g.
of(AsyncFuture<T>, boolean) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
 
of(E...) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
of(CompletionStage<T>, boolean) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
 
of(Lock) - Static method in class com.linkedin.venice.utils.locks.AutoCloseableLock
 
of(Supplier<C>) - Static method in interface com.linkedin.venice.utils.lazy.Lazy
 
of(Supplier<C>) - Static method in interface com.linkedin.venice.utils.lazy.LazyResettable
 
of(Supplier<C>, Consumer<C>) - Static method in interface com.linkedin.venice.utils.lazy.LazyResettable
 
of(Supplier<T>) - Static method in class com.linkedin.alpini.base.concurrency.Lazy
 
of(T...) - Static method in class com.linkedin.venice.utils.ComplementSet
 
OFF - Static variable in class com.linkedin.alpini.consts.Level
The OFF has the highest possible rank and is intended to turn off logging.
OFF_INT - Static variable in class com.linkedin.alpini.consts.Level
 
offer(E) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
offer(E) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Adds the specified element as the tail (last element) of this list.
offer(E, long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
offer(T) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
offer(T, long, TimeUnit) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
offerChannel(Channel) - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Offer a Channel back to the internal storage.
offerChannel(Channel) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Offer a Channel back to the internal storage.
offerFirst(E) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Inserts the specified element at the front of this list.
offerLast(E) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Inserts the specified element at the end of this list.
OFFLINE - com.linkedin.venice.helix.HelixState
 
OFFLINE - com.linkedin.venice.utils.TestWriteUtils.TestRecordType
 
OFFLINE_JOB_START_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
OFFLINE_PARTITIONS - com.linkedin.venice.router.stats.StaleVersionReason
 
OFFLINE_PUSH - com.linkedin.venice.helix.HelixPartitionState
 
OFFLINE_PUSH_INFO - com.linkedin.venice.authorization.Method
 
OFFLINE_PUSH_INFO - com.linkedin.venice.controllerapi.ControllerRoute
 
OFFLINE_PUSH_SUB_PATH - Static variable in class com.linkedin.venice.helix.ParentHelixOfflinePushAccessor
 
OFFLINE_PUSH_SUB_PATH - Static variable in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
OFFLINE_STATE - Static variable in enum com.linkedin.venice.helix.HelixState
 
OfflinePushAccessor - Interface in com.linkedin.venice.pushmonitor
Accessor to execute the CURD operations for offline push and its replicas statuses.
OfflinePushStatus - Class in com.linkedin.venice.pushmonitor
Class stores all the statuses and history of one offline push.
OfflinePushStatus(String, int, int, OfflinePushStrategy) - Constructor for class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
OfflinePushStatusInfo(ExecutionStatus) - Constructor for class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
N.B.: Test-only constructor ):
OfflinePushStatusInfo(ExecutionStatus, Long, String) - Constructor for class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
Used by single datacenter (child) controllers, hence, no extra info nor extra details
OfflinePushStatusInfo(ExecutionStatus, Long, Map<String, String>, String, Map<String, String>, Map<String, Long>) - Constructor for class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
Used by the parent controller, hence, there is extra info and details about the child
OfflinePushStatusInfo(ExecutionStatus, Map<String, String>) - Constructor for class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
N.B.: Test-only constructor ):
OfflinePushStatusJSONSerializer - Class in com.linkedin.venice.helix
Serializer used to convert the data between OfflinePushStatus and json.
OfflinePushStatusJSONSerializer() - Constructor for class com.linkedin.venice.helix.OfflinePushStatusJSONSerializer
 
OfflinePushStatusJSONSerializer.OfflinePushStatusSerializerMixin - Class in com.linkedin.venice.helix
 
OfflinePushStatusJSONSerializer.StatusSnapshotSerializerMixin - Class in com.linkedin.venice.helix
 
OfflinePushStatusSerializerMixin(String, int, int, OfflinePushStrategy) - Constructor for class com.linkedin.venice.helix.OfflinePushStatusJSONSerializer.OfflinePushStatusSerializerMixin
 
offlinePushStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
When doing off-line push, how to decide the data is ready to serve, and default is 'WAIT_N_MINUS_ONE_REPLCIA_PER_PARTITION'
offLinePushStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
OfflinePushStrategy - Enum in com.linkedin.venice.meta
Enum of strategies used to decide the when the data is ready to serve in off-line push.
offset - Variable in class com.linkedin.venice.DumpAdminMessages.AdminOperationInfo
 
offset - Variable in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
The offset of this record in Kafka
offset - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
The offset of the record in the original Kafka topic partition
offset - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
The offset of the record in the original Kafka topic partition
offset - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
offset - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
The last Kafka offset consumed successfully in this partition from version topic.
OFFSET - com.linkedin.venice.Arg
 
OFFSET - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
OFFSET_LAG - com.linkedin.davinci.ingestion.LagType
 
OFFSET_LAG_DELTA_RELAX_FACTOR_FOR_FAST_ONLINE_TRANSITION_IN_RESTART - Static variable in class com.linkedin.venice.ConfigKeys
 
OFFSET_LAG_TO_GO_ONLINE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
OFFSET_REGRESSION_DCR_ERROR - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
OFFSET_VECTOR_SCHEMA - Static variable in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
offsetForTime(PubSubTopicPartition, long) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
offsetForTime(PubSubTopicPartition, long) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the offset of the first message with a timestamp greater than or equal to the target timestamp for the specified PubSub topic-partition.
offsetForTime(PubSubTopicPartition, long) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
offsetForTime(PubSubTopicPartition, long, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
offsetForTime(PubSubTopicPartition, long, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the offset of the first message with a timestamp greater than or equal to the target timestamp for the specified PubSub topic-partition.
offsetForTime(PubSubTopicPartition, long, Duration) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
offsetLag - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
The last Kafka offset lag in this partition for fast online transition in server restart.
offsetLagThresholdToGoOnline - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
offsetLagThresholdToGoOnline - Variable in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
offsetLagThresholdToGoOnline - Variable in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
OffsetManager - Interface in com.linkedin.venice.offsets
This class records the offset for every pair(topic,partition) this node is responsible for.
offsetRecord - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Offset checkpoint info and DIV info
OffsetRecord - Class in com.linkedin.venice.offsets
If OffsetRecord is initialized with a serializer that contains SchemaReader, old version of server codes will be able to deserialize OffsetRecord that is serialized with a newer protocol version, which can happen after rolling back a server release with new protocol version to an old server release with old protocol version.
OffsetRecord(byte[], InternalAvroSpecificSerializer<PartitionState>) - Constructor for class com.linkedin.venice.offsets.OffsetRecord
 
OffsetRecord(PartitionState, InternalAvroSpecificSerializer<PartitionState>) - Constructor for class com.linkedin.venice.offsets.OffsetRecord
 
OffsetRecord(InternalAvroSpecificSerializer<PartitionState>) - Constructor for class com.linkedin.venice.offsets.OffsetRecord
 
offsetRecordArray - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
ofMany(Lock...) - Static method in class com.linkedin.venice.utils.locks.AutoCloseableLock
 
OK - Static variable in class com.linkedin.venice.grpc.GrpcErrorCodes
 
oldRmdManifest - Variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
oldServingVersionTopic - Variable in class com.linkedin.venice.kafka.protocol.VersionSwap
Name of the old source topic we are switching from.
oldValueManifest - Variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
on(char) - Static method in class com.linkedin.alpini.base.misc.Joiner
 
on(String) - Static method in class com.linkedin.alpini.base.misc.Joiner
 
onBecomeBootstrapFromOffline(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeDroppedFromBootstrap(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeDroppedFromError(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
Handles ERROR->DROPPED transition.
onBecomeDroppedFromError(Message, NotificationContext) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
A callback for Helix state transition from HelixState.ERROR_STATE to HelixState.DROPPED_STATE.
onBecomeDroppedFromOffline(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
onBecomeDroppedFromOffline(Message, NotificationContext) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
A callback for Helix state transition from HelixState.OFFLINE_STATE to HelixState.DROPPED_STATE.
onBecomeDroppedFromOffline(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeLeaderFromStandby(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
onBecomeLeaderFromStandby(Message, NotificationContext) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
A callback for Helix state transition from HelixState.STANDBY_STATE to HelixState.LEADER_STATE.
onBecomeLeaderFromStandby(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeOfflineFromDropped(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
onBecomeOfflineFromDropped(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeOfflineFromError(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
onBecomeOfflineFromError(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeOfflineFromOnline(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeOfflineFromStandby(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
onBecomeOfflineFromStandby(Message, NotificationContext) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
A callback for Helix state transition from HelixState.STANDBY_STATE to HelixState.OFFLINE_STATE.
onBecomeOfflineFromStandby(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeOnlineFromBootstrap(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeStandbyFromLeader(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
onBecomeStandbyFromLeader(Message, NotificationContext) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
A callback for Helix state transition from HelixState.LEADER_STATE to HelixState.STANDBY_STATE.
onBecomeStandbyFromLeader(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomeStandbyFromOffline(Message, NotificationContext) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModel
 
onBecomeStandbyFromOffline(Message, NotificationContext) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
A callback for Helix state transition from HelixState.OFFLINE_STATE to HelixState.STANDBY_STATE.
onBecomeStandbyFromOffline(Message, NotificationContext) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory.OnlineOfflineStateModel
 
onBecomingOfflineFromError(Message, NotificationContext) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
A callback for Helix state transition from HelixState.ERROR_STATE to HelixState.OFFLINE_STATE.
onComplete(InstrumentibleEventExecutor.Completion, boolean) - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
Invoked after completion of the task
onCompletion() - Method in class com.linkedin.davinci.callback.BytesStreamingCallback
 
onCompletion(PubSubProduceResult, Exception) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveProducerCallback
 
onCompletion(PubSubProduceResult, Exception) - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
onCompletion(PubSubProduceResult, Exception) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.PartitionWriterProducerCallback
 
onCompletion(PubSubProduceResult, Exception) - Method in class com.linkedin.venice.pubsub.adapter.PubSubProducerCallbackSimpleImpl
 
onCompletion(PubSubProduceResult, Exception) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerCallback
exception will be null if request was completed without an error.
onCompletion(PubSubProduceResult, Exception) - Method in class com.linkedin.venice.writer.CompletableFutureCallback
 
onCompletion(Optional<VeniceClientException>) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
onCompletion(Optional<VeniceClientException>) - Method in class com.linkedin.venice.client.store.streaming.ClientComputeRecordStreamDecoder
 
onCompletion(Optional<VeniceClientException>) - Method in interface com.linkedin.venice.client.store.transport.TransportClientStreamingCallback
This will be invoked when the response is fully completed.
onCompletion(Optional<Exception>) - Method in class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
 
onCompletion(Optional<Exception>) - Method in interface com.linkedin.venice.client.store.streaming.StreamingCallback
This will be invoked when the callbacks are fully executed.
onCompletion(RecordMetadata, Exception) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerCallback
 
onCompletion(T, Exception) - Method in interface com.linkedin.venice.router.streaming.StreamingCallback
The callback method that the user can implement to do asynchronous handling of the response.
onConnect(Channel, Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
onConnect(Channel, Promise<Channel>) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
onControllerChange(NotificationContext) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
onCustomizedViewAdded(PartitionAssignment) - Method in class com.linkedin.venice.controller.stats.AggPartitionHealthStats
 
onCustomizedViewAdded(PartitionAssignment) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
onCustomizedViewAdded(PartitionAssignment) - Method in interface com.linkedin.venice.meta.RoutingDataRepository.RoutingDataChangedListener
 
onCustomizedViewAdded(PartitionAssignment) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
onCustomizedViewChange(PartitionAssignment) - Method in class com.linkedin.venice.controller.stats.AggPartitionHealthStats
 
onCustomizedViewChange(PartitionAssignment) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
onCustomizedViewChange(PartitionAssignment) - Method in interface com.linkedin.venice.meta.RoutingDataRepository.RoutingDataChangedListener
 
onCustomizedViewChange(PartitionAssignment) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
onCustomizedViewDataChange(RoutingTableSnapshot) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
onCustomizedViewDataChange(RoutingTableSnapshot) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
 
onCustomizedViewDataChange(RoutingTableSnapshot) - Method in class com.linkedin.venice.helix.HelixExternalViewRepository
 
onDataReceived(ByteBuffer) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
onDataReceived(ByteBuffer) - Method in class com.linkedin.venice.client.store.streaming.ClientComputeRecordStreamDecoder
 
onDataReceived(ByteBuffer) - Method in interface com.linkedin.venice.client.store.transport.TransportClientStreamingCallback
This will be invoked when a new data chunk is available.
onDeserializationCompletion(Optional<Exception>, int, int) - Method in class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
 
onDeserializationCompletion(Optional<Exception>, int, int) - Method in interface com.linkedin.venice.client.store.streaming.TrackingStreamingCallback
This will be invoked when Venice Client deserialization is done.
ONE_FUTURE_PER_RECORD - com.linkedin.venice.client.store.deserialization.BatchDeserializerType
Deprecated.
onEndIngestionTask() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
This function is called as a lifecycle event at the end of an ingestion task By default, it performs no operation.
onError(Throwable) - Method in class com.linkedin.venice.fastclient.transport.R2TransportClient.R2TransportClientCallback
 
onExceedQuota(Time, String, long, long, long) - Method in interface com.linkedin.venice.throttle.EventThrottlingStrategy
This method will be executed by event throttler once the usage exceeded the quota.
onExec(InstrumentibleEventExecutor.Completion) - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
Invoked on the executing thread before execution of the task
onExternalViewChange(PartitionAssignment) - Method in class com.linkedin.venice.controller.stats.AggPartitionHealthStats
 
onExternalViewChange(PartitionAssignment) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
onExternalViewChange(PartitionAssignment) - Method in interface com.linkedin.venice.meta.RoutingDataRepository.RoutingDataChangedListener
Handle routing data changed event.
onExternalViewChange(PartitionAssignment) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
onExternalViewDataChange(RoutingTableSnapshot) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
onExternalViewDataChange(RoutingTableSnapshot) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
 
onExternalViewDataChange(RoutingTableSnapshot) - Method in class com.linkedin.venice.helix.HelixExternalViewRepository
 
onFinish(ISuite) - Method in class com.linkedin.venice.testng.VeniceSuiteListener
 
ONGOING_INCREMENTAL_PUSH_STATUSES_KEY - Static variable in class com.linkedin.venice.common.PushStatusStoreUtils
 
ONGOING_INCREMENTAL_PUSHES - com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
 
ONGOING_PUSH - com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
 
onHeaderReceived(Map<String, String>) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
 
onHeaderReceived(Map<String, String>) - Method in class com.linkedin.venice.client.store.streaming.ClientComputeRecordStreamDecoder
 
onHeaderReceived(Map<String, String>) - Method in interface com.linkedin.venice.client.store.transport.TransportClientStreamingCallback
This will be invoked when headers are available.
onIdealStateChange(List<IdealState>, NotificationContext) - Method in class com.linkedin.venice.helix.HelixExternalViewRepository
 
onInstanceConfigChange(List<InstanceConfig>, NotificationContext) - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
This function will assign a unique group id per group.
ONLINE - com.linkedin.venice.meta.VersionStatus
 
OnlineInstanceFinder - Interface in com.linkedin.venice.meta
Look up online instances related to a topic's partition.
OnlineProducerFactory - Class in com.linkedin.venice.producer.online
 
OnlineProducerFactory() - Constructor for class com.linkedin.venice.producer.online.OnlineProducerFactory
 
OnlineVeniceProducer<K,​V> - Class in com.linkedin.venice.producer.online
An implementation of a VeniceProducer suitable for online applications.
onPartitionStatusChange(OfflinePushStatus) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
onPartitionStatusChange(OfflinePushStatus) - Method in class com.linkedin.venice.pushmonitor.PartitionStatusBasedPushMonitor
 
onPartitionStatusChange(String, ReadOnlyPartitionStatus) - Method in class com.linkedin.venice.controller.stats.AggPartitionHealthStats
 
onPartitionStatusChange(String, ReadOnlyPartitionStatus) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
onPartitionStatusChange(String, ReadOnlyPartitionStatus) - Method in interface com.linkedin.venice.meta.RoutingDataRepository.RoutingDataChangedListener
 
onPartitionStatusChange(String, ReadOnlyPartitionStatus) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
onPartitionStatusChange(String, ReadOnlyPartitionStatus) - Method in interface com.linkedin.venice.pushmonitor.PartitionStatusListener
 
onRawRecordReceived(K, V) - Method in class com.linkedin.venice.client.store.streaming.ClientComputeRecordStreamDecoder.Callback
Called for each unprocessed value record found in the stream
onRecordDeserialized() - Method in class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
 
onRecordDeserialized() - Method in interface com.linkedin.venice.client.store.streaming.TrackingStreamingCallback
This will be invoked when any record deserialization happens.
onRecordReceived(byte[], byte[]) - Method in class com.linkedin.davinci.callback.BytesStreamingCallback
 
onRecordReceived(K, V) - Method in class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
 
onRecordReceived(K, V) - Method in interface com.linkedin.venice.client.store.streaming.StreamingCallback
This function will be invoked when some records are ready to be consumed.
onRemoteComputeStateChange(boolean) - Method in class com.linkedin.venice.client.store.streaming.ClientComputeRecordStreamDecoder.Callback
 
onRepositoryChanged(Collection<String>) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepository
HelixReadOnlyZKSharedSystemStoreRepository is overriding this function to filter out stores, which are not necessary to put a watch against, and if this logic to monitor the zk store repository gets changed in the future, we need to update HelixReadOnlyZKSharedSystemStoreRepository accordingly.
onRepositoryChanged(Collection<String>) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
This function is used to filter out non system stores to avoid unnecessary zk watches against the newly added regular stores.
onRoutingDataDeleted(String) - Method in class com.linkedin.venice.controller.stats.AggPartitionHealthStats
 
onRoutingDataDeleted(String) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
onRoutingDataDeleted(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository.RoutingDataChangedListener
 
onRoutingDataDeleted(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
onRoutingTableChange(RoutingTableSnapshot, Object) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
onRoutingTableChange(RoutingTableSnapshot, Object) - Method in class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
 
onSchedule(InstrumentibleEventExecutor.Completion) - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
Invoked when the task is scheduled for later execution.
onStart(ISuite) - Method in class com.linkedin.venice.testng.VeniceSuiteListener
 
onStartIngestionTask() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
This function is called as a lifecycle event at the beginning of an ingestion task.
onStoreChanged(Store) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepository
 
onSubmit(InstrumentibleEventExecutor.Completion) - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
Invoked when the task is scheduled for immediate execution
onSuccess(RestResponse) - Method in class com.linkedin.venice.fastclient.transport.R2TransportClient.R2TransportClientCallback
 
onTestFailedButWithinSuccessPercentage(ITestResult) - Method in class com.linkedin.venice.testng.VeniceTestListener
 
onTestFailure(ITestResult) - Method in class com.linkedin.venice.testng.VeniceTestListener
 
onTestSkipped(ITestResult) - Method in class com.linkedin.venice.testng.VeniceTestListener
 
onTestStart(ITestResult) - Method in class com.linkedin.venice.testng.VeniceTestListener
 
onTestSuccess(ITestResult) - Method in class com.linkedin.venice.testng.VeniceTestListener
 
open() - Method in class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
Open a new Http2StreamChannel to use.
open(VenicePulsarSinkConfig, VeniceSystemProducer, SinkContext) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSink
to simplify unit testing
open(EventLoop) - Method in class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
 
open(Promise<Http2StreamChannel>, EventLoop) - Method in class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
Open a new Http2StreamChannel to use and notifies the given Promise.
open(String) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
Open the connection pool to the specified host and port.
open(String) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
open(Map<String, Object>, SinkContext) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSink
 
open(Map<String, String>, Optional<Supplier<byte[]>>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
open(Options, String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBThrottler
Open RocksDB in read-write mode with provided column family descriptors and handlers.
OPEN_STORAGE_ENGINE - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
OPEN_VENICE_WRITER_COUNT - Static variable in class com.linkedin.venice.writer.VeniceWriter
A static counter shared by all VeniceWriter instances to track the number of active VeniceWriter
open0(ChannelHandlerContext, Promise<Http2StreamChannel>, EventLoop) - Method in class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
Deprecated.
should not be used directly. Use EspressoHttp2StreamChannelBootstrap.open() or
openReadOnly(Options, String, List<ColumnFamilyDescriptor>, List<ColumnFamilyHandle>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBThrottler
Open RocksDB in read-only mode with provided column family descriptors and handlers.
openStorageEngine(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
openStore(VeniceStoreVersionConfig, Supplier<StoreVersionState>) - Method in class com.linkedin.davinci.storage.StorageService
Creates a StorageEngineFactory for the persistence type if not already present.
openStoreForNewPartition(VeniceStoreVersionConfig, int, Supplier<StoreVersionState>) - Method in class com.linkedin.davinci.storage.StorageService
 
operation - Variable in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
OPERATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
operationComplete(AsyncFuture<T>) - Method in interface com.linkedin.alpini.base.concurrency.AsyncFutureListener
Invoked when the operation associated with the AsyncFuture has been completed.
OperationNotAllowedException - Exception in com.linkedin.venice.exceptions
 
OperationNotAllowedException(String) - Constructor for exception com.linkedin.venice.exceptions.OperationNotAllowedException
 
operations - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
operations - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
operations - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
operations - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
operations - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
operationType - Variable in class com.linkedin.venice.compute.protocol.request.ComputeOperation
Supported operation type: 0 -> DotProduct
operationType - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
0 => StoreCreation, 1 => ValueSchemaCreation, 2 => PauseStore, 3 => ResumeStore, 4 => KillOfflinePushJob, 5 => DisableStoreRead, 6 => EnableStoreRead, 7=> DeleteAllVersions, 8=> SetStoreOwner, 9=> SetStorePartitionCount, 10=> SetStoreCurrentVersion, 11=> UpdateStore, 12=> DeleteStore, 13=> DeleteOldVersion, 14=> MigrateStore, 15=> AbortMigration, 16=>AddVersion, 17=> DerivedSchemaCreation, 18=>SupersetSchemaCreation, 19=>EnableNativeReplicationForCluster, 20=>MetadataSchemaCreation, 21=>EnableActiveActiveReplicationForCluster, 25=>CreatePersona, 26=>DeletePersona, 27=>UpdatePersona, 28=>RollbackCurrentVersion, 29=>RollforwardCurrentVersion
operationType - Variable in class com.linkedin.venice.DumpAdminMessages.AdminOperationInfo
 
OptimizedBinaryDecoder - Class in org.apache.avro.io
This class is used to optimize bytes field decoding.
OptimizedBinaryDecoderFactory - Class in org.apache.avro.io
 
OptimizedKafkaValueSerializer - Class in com.linkedin.venice.serialization.avro
This class is to reuse the original array for put payload of each message to reduce the unnecessary byte array allocation.
OptimizedKafkaValueSerializer() - Constructor for class com.linkedin.venice.serialization.avro.OptimizedKafkaValueSerializer
 
OptimizedKafkaValueSerializer(BiConsumer<Integer, Schema>) - Constructor for class com.linkedin.venice.serialization.avro.OptimizedKafkaValueSerializer
 
option(ChannelOption<T>, T) - Method in class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
Allow to specify a ChannelOption which is used for the Http2StreamChannel instances once they got created.
optional() - Method in annotation type com.linkedin.alpini.cli.CLIArgument
Set to true if the default action is inaction.
OPTIONS - com.linkedin.venice.authorization.Method
 
orElse(C) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
orElse(T) - Method in interface com.linkedin.venice.utils.lazy.Lazy
Return the value if initialized, otherwise return other.
orElse(T) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
orElseGet(Supplier<? extends C>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
orElseGet(Supplier<? extends T>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
Return the value if initialized, otherwise invoke other and return the result of that invocation.
orElseGet(Supplier<? extends T>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
orElseThrow(Supplier<? extends X>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
Return the contained value, if initialized, otherwise throw an exception to be created by the provided supplier.
orElseThrow(Supplier<? extends X>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
 
orElseThrow(Supplier<? extends X>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
org.apache.avro.generic - package org.apache.avro.generic
 
org.apache.avro.io - package org.apache.avro.io
 
org.apache.avro.specific - package org.apache.avro.specific
 
OTHER_EXCEPTION - com.linkedin.alpini.base.concurrency.AsyncFuture.Status
 
otherClusters - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Other Venice clusters that the store is materializing in either because of store migration or offset load from the source cluster.
OutboundByteBufAggregator - Class in com.linkedin.alpini.netty4.handlers
SSL uses 16kb application message packets.
OutboundByteBufAggregator() - Constructor for class com.linkedin.alpini.netty4.handlers.OutboundByteBufAggregator
 
OutboundByteBufAggregator(int) - Constructor for class com.linkedin.alpini.netty4.handlers.OutboundByteBufAggregator
 
OutboundByteBufAggregator(int, ByteBufAllocator) - Constructor for class com.linkedin.alpini.netty4.handlers.OutboundByteBufAggregator
 
OutboundHttpWrapperHandler - Class in com.linkedin.venice.listener
wraps raw bytes into an HTTP response object that HttpServerCodec expects
OutboundHttpWrapperHandler(StatsHandler) - Constructor for class com.linkedin.venice.listener.OutboundHttpWrapperHandler
 
OUTPUT_RECORD_COUNT_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
outputRecordCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
overallStatus - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
OverflowException(String) - Constructor for exception com.linkedin.alpini.netty4.ssl.FusedSslHandler.OverflowException
 
overrideSetActiveVersion(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
owner - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
owner - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
owner - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
owner - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
owner - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Owner of this store.
OWNER - com.linkedin.venice.Arg
 
OWNER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
OwnerResponse - Class in com.linkedin.venice.controllerapi
 
OwnerResponse() - Constructor for class com.linkedin.venice.controllerapi.OwnerResponse
 
owners - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
owners - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
OWNERS_DOES_NOT_EXIST_REGEX - Static variable in class com.linkedin.venice.utils.TestStoragePersonaUtils
 

P

pack() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
 
pack() - Method in class com.linkedin.alpini.base.concurrency.ThreadedAccumulator
 
Pair<F,​S> - Class in com.linkedin.alpini.base.misc
A simple container for a pair of (2) values.
Pair<F,​S> - Class in com.linkedin.venice.utils
Deprecated.
Instead of this, please create a dedicated class with well-named, non-generic (potentially primitive) properties and getters.
Pair(F, S) - Constructor for class com.linkedin.alpini.base.misc.Pair
Constructor for a pair.
Pair(F, S) - Constructor for class com.linkedin.venice.utils.Pair
Deprecated.
Use the static factory method Pair.create(Object, Object) instead of this where possible.
ParamBuilder() - Constructor for class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
parameters() - Method in interface com.linkedin.alpini.base.misc.HeaderUtils.ContentType
 
params - Variable in class com.linkedin.venice.controllerapi.QueryParams
 
Params() - Constructor for class com.linkedin.venice.datarecovery.Command.Params
 
Params() - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
 
Params() - Constructor for class com.linkedin.venice.datarecovery.MonitorCommand.Params
 
Params() - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
 
PARENT_CONTROLLER_MAX_ERRORED_TOPIC_NUM_TO_KEEP - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to control how many errored topics we are going to keep in parent cluster.
PARENT_CONTROLLER_REGION_NAME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
This config specifies the region identifier where parent controller is running
PARENT_CONTROLLER_WAITING_TIME_FOR_CONSUMPTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
When the parent controller receives an admin write operation, it replicates that message to the admin kafka stream.
PARENT_DIRECTORY - com.linkedin.venice.Arg
 
PARENT_KAFKA_CLUSTER_FABRIC_LIST - Static variable in class com.linkedin.venice.ConfigKeys
A list of potential parent fabrics.
parentContext() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
 
ParentControllerConfigUpdateUtils - Class in com.linkedin.venice.controller.util
This class is a utility class for Parent Controller store update logics.
ParentControllerConfigUpdateUtils() - Constructor for class com.linkedin.venice.controller.util.ParentControllerConfigUpdateUtils
 
parentControllerRegionD2ZkHosts - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
ParentHelixOfflinePushAccessor - Class in com.linkedin.venice.helix
 
ParentHelixOfflinePushAccessor(ZkClient, HelixAdapterSerializer) - Constructor for class com.linkedin.venice.helix.ParentHelixOfflinePushAccessor
 
parse(String) - Static method in class com.linkedin.alpini.base.misc.TimeValue
Parse a TimeValue from a serialized string
parse(String) - Static method in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
Deprecated.
 
parse(String) - Static method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
parse(String) - Static method in class com.linkedin.venice.schema.vson.VsonSchemaAdapter
Deprecated.
 
parse(String[]) - Method in class com.linkedin.alpini.cli.CLIArgumentParser
Parse the given command line and return the arguments, or null if the arguments are invalid.
parse(String[]) - Method in interface com.linkedin.alpini.cli.CLIParser
 
parseAdminHttpRequest(HttpRequest) - Static method in class com.linkedin.venice.listener.request.AdminRequest
 
parseAndCreate(byte[]) - Static method in class com.linkedin.davinci.store.record.ValueRecord
 
parseBooleanFromString(String, String) - Static method in class com.linkedin.venice.utils.Utils
Since Boolean.parseBoolean(String) does not throw exception and will always return 'false' for any string that are not equal to 'true', We validate the string by our own.
parseClusterMap(VeniceProperties, String) - Static method in class com.linkedin.venice.controller.VeniceControllerConfig
 
parseClusterMap(VeniceProperties, String, Boolean) - Static method in class com.linkedin.venice.controller.VeniceControllerConfig
The config should follow the format below: CHILD_CLUSTER_URL_PREFIX.fabricName1=controllerUrls_in_fabric1 CHILD_CLUSTER_URL_PREFIX.fabricName2=controllerUrls_in_fabric2 This helper function will parse the config with above format and return a Map from data center to its controller urls.
parseCommaSeparatedStringToList(String) - Static method in class com.linkedin.venice.utils.Utils
 
parseCommaSeparatedStringToSet(String) - Static method in class com.linkedin.venice.utils.Utils
 
parseComputeRequest(FullHttpRequest) - Static method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
 
parseContentType(String) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
 
parseDataAsByteBuf(byte[]) - Static method in class com.linkedin.davinci.store.record.ValueRecord
 
parseDataAsNIOByteBuffer(byte[]) - Static method in class com.linkedin.davinci.store.record.ValueRecord
 
parseDate(String) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
parseDatetimeToDate(String) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Parse the given String date and time to a millisecond value.
parseDatetimeToMillis(String) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Parse the given String date and time to a millisecond value.
parseDelimitedFrom(InputStream) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseDelimitedFrom(InputStream) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseDelimitedFrom(InputStream, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(byte[]) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(byte[]) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(byte[], ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(ByteString) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(ByteString) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(ByteString, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(CodedInputStream) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(CodedInputStream) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(CodedInputStream, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(InputStream) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(InputStream) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(InputStream, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(ByteBuffer) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(ByteBuffer) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parseFrom(ByteBuffer, ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseGetHttpRequest(HttpRequest) - Static method in class com.linkedin.venice.listener.request.CurrentVersionRequest
 
parseGetHttpRequest(HttpRequest) - Static method in class com.linkedin.venice.listener.request.DictionaryFetchRequest
 
parseGetHttpRequest(HttpRequest) - Static method in class com.linkedin.venice.listener.request.GetRouterRequest
 
parseGetHttpRequest(HttpRequest) - Static method in class com.linkedin.venice.listener.request.MetadataFetchRequest
 
parseGetHttpRequest(HttpRequest) - Static method in class com.linkedin.venice.listener.request.TopicPartitionIngestionContextRequest
 
parseHostFromHelixNodeIdentifier(String) - Static method in class com.linkedin.venice.utils.Utils
 
parseIdentityFromCert(X509Certificate) - Method in class com.linkedin.venice.authorization.DefaultIdentityParser
Returns a string representation of the X.500 distinguished name using the format defined in RFC 2253.
parseIdentityFromCert(X509Certificate) - Method in interface com.linkedin.venice.authorization.IdentityParser
Returns a string representation of the identity represented by the X509Certificate.
parseIntFromString(String, String) - Static method in class com.linkedin.venice.utils.Utils
 
parseJsonMapFromString(String, String) - Static method in class com.linkedin.venice.utils.Utils
For String-String key-value map config, we expect the command-line interface users to use JSON format to represent it.
parseKafkaClusterMap(String) - Static method in class com.linkedin.davinci.config.VeniceConfigLoader
 
parseKafkaClusterMap(String, String) - Static method in class com.linkedin.davinci.config.VeniceConfigLoader
The file contains the following info: The otherUrls field is used to translate URLs coming from other processes (e.g.
parseLongFromString(String, String) - Static method in class com.linkedin.venice.utils.Utils
 
parseMultiGetGrpcRequest(VeniceClientRequest) - Static method in class com.linkedin.venice.listener.request.MultiGetRouterRequestWrapper
 
parseMultiGetHttpRequest(FullHttpRequest) - Static method in class com.linkedin.venice.listener.request.MultiGetRouterRequestWrapper
 
parsePartitionIdFromPartitionDbName(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
parsePortFromHelixNodeIdentifier(String) - Static method in class com.linkedin.venice.utils.Utils
 
parseProperties(File) - Static method in class com.linkedin.venice.utils.Utils
Given a .property file, reads into a Venice Props object
parseProperties(String) - Static method in class com.linkedin.venice.utils.Utils
Given a filePath, reads into a Venice Props object
parseProperties(String, String, boolean) - Static method in class com.linkedin.venice.utils.Utils
Generate VeniceProperties object from a given directory, file.
parser() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
 
parser() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
 
parseRegionsFilterList(String) - Static method in class com.linkedin.venice.utils.RegionUtils
A helper function to split a region list with RegionUtils.REGION_FILTER_LIST_SEPARATOR
parseRequest(HttpRequest) - Static method in class com.linkedin.venice.router.api.VenicePathParserHelper
 
parseResourceUri(String) - Method in interface com.linkedin.alpini.router.api.ResourcePathParser
 
parseResourceUri(String) - Method in class com.linkedin.venice.router.api.VenicePathParser
 
parseResourceUri(String, BASIC_HTTP_REQUEST) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
parseResourceUri(String, HTTP_REQUEST) - Method in interface com.linkedin.alpini.router.api.ExtendedResourcePathParser
 
parseResourceUri(String, HTTP_REQUEST) - Method in class com.linkedin.venice.router.api.VenicePathParser
 
parseRetryThresholdForBatchGet(String) - Static method in class com.linkedin.venice.router.VeniceRouterConfig
The expected config format is like the following: "1-10:20,11-50:50,51-200:80,201-:1000"
parseRFC1123Date(String) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
 
parseRole(String, Headers) - Method in interface com.linkedin.alpini.router.api.RoleFinder
 
parseRole(String, Headers) - Method in class com.linkedin.venice.router.api.VeniceRoleFinder
 
parseRoles(String, Headers) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
parseSchemaFromJSON(String, boolean) - Static method in class com.linkedin.venice.schema.AvroSchemaParseUtils
 
parseSchemaFromJSONLooseValidation(String) - Static method in class com.linkedin.venice.schema.AvroSchemaParseUtils
 
parseSchemaFromJSONStrictValidation(String) - Static method in class com.linkedin.venice.schema.AvroSchemaParseUtils
 
parseSchemaId(byte[]) - Static method in class com.linkedin.davinci.store.record.ValueRecord
 
parseStandardOutput() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
 
parseStoreFromKafkaTopicName(String) - Static method in interface com.linkedin.venice.meta.Version
Parse the store name of the given topic accordingly depending on the type of the kafka topic.
parseStoreFromRealTimeTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
parseStoreFromStreamReprocessingTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
parseStoreFromVersionTopic(String) - Static method in interface com.linkedin.venice.meta.Version
 
parseStoreFromViewTopic(String) - Static method in class com.linkedin.venice.views.VeniceView
 
parseStoreNameFromPartitionDbName(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
parseTimespanToMillis(String) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Parse the given String timespan to a millisecond value.
parseVersionFromKafkaTopicName(String) - Static method in interface com.linkedin.venice.meta.Version
This API works for both version topic and stream-reprocessing topics; other topic names will fail with IllegalArgumentException.
parseVersionFromVersionTopicName(String) - Static method in interface com.linkedin.venice.meta.Version
This API only works for version topic; other topic names will fail with IllegalArgumentException.
parseVersionFromViewTopic(String) - Static method in class com.linkedin.venice.views.VeniceView
 
PARTIAL_UPDATE - com.linkedin.venice.authorization.Method
 
PARTIALLY_ONLINE - com.linkedin.venice.meta.VersionStatus
 
PARTIALLY_UPDATED - com.linkedin.davinci.schema.merge.UpdateResultStatus
 
PARTICIPANT_MESSAGE_CONSUMPTION_DELAY_MS - Static variable in class com.linkedin.venice.ConfigKeys
Minimum delay between each cycle where the storage node polls the participant message store to see if any of its ongoing push job has been killed.
PARTICIPANT_MESSAGE_STORE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Flag to enable the participant message store setup and write operations to the store.
PARTICIPANT_MESSAGE_SYSTEM_STORE_VALUE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Value schema for participant system stores.
PARTICIPANT_STORE - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
ParticipantMessageKey - Class in com.linkedin.venice.participant.protocol
 
ParticipantMessageKey() - Constructor for class com.linkedin.venice.participant.protocol.ParticipantMessageKey
Default constructor.
ParticipantMessageKey(CharSequence, Integer) - Constructor for class com.linkedin.venice.participant.protocol.ParticipantMessageKey
All-args constructor.
ParticipantMessageType - Enum in com.linkedin.venice.participant.protocol.enums
 
ParticipantMessageValue - Class in com.linkedin.venice.participant.protocol
 
ParticipantMessageValue() - Constructor for class com.linkedin.venice.participant.protocol.ParticipantMessageValue
Default constructor.
ParticipantMessageValue(Integer, Object) - Constructor for class com.linkedin.venice.participant.protocol.ParticipantMessageValue
All-args constructor.
ParticipantStateTransitionStats - Class in com.linkedin.davinci.stats
This class is used to track the thread pool stats for the state transitions of the participant.
ParticipantStateTransitionStats(MetricsRepository, ThreadPoolExecutor, String) - Constructor for class com.linkedin.davinci.stats.ParticipantStateTransitionStats
 
ParticipantStoreConsumptionStats - Class in com.linkedin.davinci.stats
 
ParticipantStoreConsumptionStats(MetricsRepository, String) - Constructor for class com.linkedin.davinci.stats.ParticipantStoreConsumptionStats
 
ParticipantStoreConsumptionTask - Class in com.linkedin.davinci.kafka.consumer
 
ParticipantStoreConsumptionTask(StoreIngestionService, ClusterInfoProvider, ParticipantStoreConsumptionStats, ClientConfig<ParticipantMessageValue>, long, ICProvider) - Constructor for class com.linkedin.davinci.kafka.consumer.ParticipantStoreConsumptionTask
 
partition - Variable in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter.SendMessageParameters
 
partition() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionInfo
The partition id
Partition - Class in com.linkedin.venice.meta
Class defines the partition in Venice.
Partition(int, EnumMap<HelixState, List<Instance>>, EnumMap<ExecutionStatus, List<Instance>>) - Constructor for class com.linkedin.venice.meta.Partition
 
PARTITION - com.linkedin.venice.Arg
 
PARTITION_COLUMN_NAME - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
PARTITION_COUNT - com.linkedin.venice.Arg
 
PARTITION_COUNT - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PARTITION_COUNT - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
PARTITION_COUNT_ROUND_UP_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
If "enable.partition.count.round.up" is enabled, this config defines the round up size.
PARTITION_COUNTS - Static variable in class com.linkedin.venice.utils.DataProviderUtils
 
PARTITION_DETAIL_ENABLED - com.linkedin.venice.Arg
 
PARTITION_DETAIL_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PARTITION_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
PARTITION_NUM_FOR_ADMIN_TOPIC - Static variable in class com.linkedin.venice.controller.kafka.AdminTopicUtils
 
PARTITION_STATE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to persist the state of a partition in Storage Nodes, including offset, Data Ingest Validation state, etc.
PARTITION_STATUS_BASED - com.linkedin.venice.pushmonitor.PushMonitorType
 
PARTITION_WISE_SHARED_CONSUMER_ASSIGNMENT_STRATEGY - com.linkedin.davinci.kafka.consumer.KafkaConsumerService.ConsumerAssignmentStrategy
 
PartitionAssignment - Class in com.linkedin.venice.meta
This class represent the assignments of one resource including all of assigned partitions and expected number of partitions.
PartitionAssignment(String, int) - Constructor for class com.linkedin.venice.meta.PartitionAssignment
 
PartitionConsumptionState - Class in com.linkedin.davinci.kafka.consumer
This class is used to maintain internal state for consumption of each partition.
PartitionConsumptionState(int, int, OffsetRecord, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
PartitionConsumptionState.TransientRecord - Class in com.linkedin.davinci.kafka.consumer
This immutable class holds a association between a key and value and the source offset of the consumed message.
partitionConsumptionStateMap - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Per-partition consumption state map
partitionConsumptionStates - Variable in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Consumption states snapshots for the requested partitions
partitionCount - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
partitionCount - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
partitionCount - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
partitionCount - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
partitionCount - Variable in class com.linkedin.venice.metadata.response.VersionProperties
Partition count of the current version
partitionCount - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
partitionCount - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Default partition count for all of versions in this store.
partitionCount - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Partition count of this version.
PartitionDetail - Class in com.linkedin.venice.meta
 
PartitionDetail() - Constructor for class com.linkedin.venice.meta.PartitionDetail
 
PartitionDetail(int) - Constructor for class com.linkedin.venice.meta.PartitionDetail
 
PartitionDispatchHandler<H,​P extends ResourcePath<K>,​K,​HTTP_REQUEST extends BasicRequest,​HTTP_RESPONSE,​HTTP_RESPONSE_STATUS> - Interface in com.linkedin.alpini.router.api
 
PartitionDispatchHandler4<H,​P extends ResourcePath<K>,​K> - Interface in com.linkedin.alpini.router.api
 
PARTITIONER_CLASS - com.linkedin.venice.Arg
 
PARTITIONER_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
A config specifies which partitioning scheme should be used by VenicePushJob.
PARTITIONER_CLASS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PARTITIONER_PARAMS - com.linkedin.venice.Arg
 
PARTITIONER_PARAMS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
partitionerClass - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
partitionerClass - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
partitionerClass - Variable in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
partitionerClass - Variable in class com.linkedin.venice.metadata.response.VersionProperties
Partitioner class name
partitionerClass - Variable in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
partitionerConfig - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
partitionerConfig - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
partitionerConfig - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
partitionerConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
partitionerConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Config for custom partitioning.
PartitionerConfig - Class in com.linkedin.venice.meta.systemstore.schemas
 
PartitionerConfig - Interface in com.linkedin.venice.meta
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
PartitionerConfig() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
Default constructor.
PartitionerConfig(Integer, CharSequence, Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
All-args constructor.
PartitionerConfigImpl - Class in com.linkedin.venice.meta
 
PartitionerConfigImpl() - Constructor for class com.linkedin.venice.meta.PartitionerConfigImpl
 
PartitionerConfigImpl(String, Map<String, String>, int) - Constructor for class com.linkedin.venice.meta.PartitionerConfigImpl
 
PartitionerConfigRecord - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
PartitionerConfigRecord() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
Default constructor.
PartitionerConfigRecord(CharSequence, Map<CharSequence, CharSequence>, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
All-args constructor.
PartitionerConfigSerializerMixin(String, Map<String, String>, int) - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer.PartitionerConfigSerializerMixin
 
partitionerParams - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
partitionerParams - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
partitionerParams - Variable in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
partitionerParams - Variable in class com.linkedin.venice.metadata.response.VersionProperties
Partitioner parameters
partitionerParams - Variable in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
PARTITIONERS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PartitionerSchemaMismatchException - Exception in com.linkedin.venice.exceptions
 
PartitionerSchemaMismatchException() - Constructor for exception com.linkedin.venice.exceptions.PartitionerSchemaMismatchException
 
PartitionerSchemaMismatchException(String) - Constructor for exception com.linkedin.venice.exceptions.PartitionerSchemaMismatchException
 
PartitionerSchemaMismatchException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.PartitionerSchemaMismatchException
 
PartitionerSchemaMismatchException(Throwable) - Constructor for exception com.linkedin.venice.exceptions.PartitionerSchemaMismatchException
 
partitionFinder(AsyncPartitionFinder<K>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
partitionFinder(PartitionFinder<K>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
partitionFinder(PartitionFinder<K>, Executor) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
PartitionFinder<K> - Interface in com.linkedin.alpini.router.api
Provides methods to find the partition name for a piece of data.
PartitionHealthStats - Class in com.linkedin.venice.controller.stats
Resource level partition health stats.
PartitionHealthStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.PartitionHealthStats
 
PartitionHealthStats(String) - Constructor for class com.linkedin.venice.controller.stats.PartitionHealthStats
Only for test usage.
partitionId - Variable in class com.linkedin.davinci.store.AbstractStoragePartition
 
partitionId - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
partitionId - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
The partition which this state snapshot belongs to.
partitionId - Variable in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Partition that current key belongs to
partitionId - Variable in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
partitionId - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
partitionId - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
partitionId - Variable in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Partition that current key belongs to
partitionNum - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
partitionNum - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
partitionPushStatusAccessorFuture - Variable in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
PartitionResponse - Class in com.linkedin.venice.controllerapi
 
PartitionResponse() - Constructor for class com.linkedin.venice.controllerapi.PartitionResponse
 
partitionsFor(PubSubTopic) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
Retrieves the list of partitions associated with a given Pub-Sub topic.
partitionsFor(PubSubTopic) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Retrieves the list of partitions associated with a given Pub-Sub topic.
partitionsFor(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
partitionsFor(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
PartitionSorter - Class in com.linkedin.venice.hadoop.spark.datawriter.partition
Sort the rows based on the key and value in ascending order using unsigned byte comparison.
PartitionSorter() - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.partition.PartitionSorter
 
PartitionState - Class in com.linkedin.venice.kafka.protocol.state
This record holds the state necessary for a consumer to checkpoint its progress when consuming a Venice partition.
PartitionState() - Constructor for class com.linkedin.venice.kafka.protocol.state.PartitionState
Default constructor.
PartitionState(Long, Long, Boolean, Long, Long, Map<CharSequence, CharSequence>, IncrementalPush, CharSequence, Long, Map<String, Long>, Long, GUID, CharSequence, Map<CharSequence, ProducerPartitionState>, Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.kafka.protocol.state.PartitionState
All-args constructor.
PartitionStatus - Class in com.linkedin.venice.pushmonitor
Class stores the status of one partition including all the replicas statuses in this partition.
PartitionStatus(int) - Constructor for class com.linkedin.venice.pushmonitor.PartitionStatus
 
PartitionStatusBasedPushMonitor - Class in com.linkedin.venice.pushmonitor
An implementation of AbstractPushMonitor that listens to ZK PartitionStatus to determine the push status.
PartitionStatusBasedPushMonitor(String, OfflinePushAccessor, StoreCleaner, ReadWriteStoreRepository, RoutingDataRepository, AggPushHealthStats, RealTimeTopicSwitcher, ClusterLockManager, String, List<String>, HelixAdminClient, VeniceControllerConfig, PushStatusStoreReader, DisabledPartitionStats) - Constructor for class com.linkedin.venice.pushmonitor.PartitionStatusBasedPushMonitor
 
PartitionStatusJSONSerializer - Class in com.linkedin.venice.helix
Serializer used to convert the data between PartitionStatus and json.
PartitionStatusJSONSerializer() - Constructor for class com.linkedin.venice.helix.PartitionStatusJSONSerializer
 
PartitionStatusJSONSerializer.PartitionStatusSerializerMixin - Class in com.linkedin.venice.helix
 
PartitionStatusJSONSerializer.ReplicaStatusSerializerMixin - Class in com.linkedin.venice.helix
 
PartitionStatusListener - Interface in com.linkedin.venice.pushmonitor
Listener used to listen the data change of partition status.
PartitionStatusSerializerMixin(int) - Constructor for class com.linkedin.venice.helix.PartitionStatusJSONSerializer.PartitionStatusSerializerMixin
 
partitionToPendingConsumerActionCountMap - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
PartitionTracker - Class in com.linkedin.davinci.validation
This class maintains state about all the upstream producers for a given partition.
PartitionTracker(String, int) - Constructor for class com.linkedin.davinci.validation.PartitionTracker
 
PartitionTracker.DIVErrorMetricCallback - Interface in com.linkedin.davinci.validation
 
partitionTrackerCreator - Variable in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
 
partitionTrackers - Variable in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
Keeps track of every upstream producer this consumer task has seen so far for each partition.
PartitionUtils - Class in com.linkedin.venice.utils
 
PartitionUtils() - Constructor for class com.linkedin.venice.utils.PartitionUtils
 
PartitionWiseKafkaConsumerService - Class in com.linkedin.davinci.kafka.consumer
PartitionWiseKafkaConsumerService is used to allocate share consumer from consumer pool at partition granularity.
partitionWriterCloseCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
PartitionWriterProducerCallback() - Constructor for class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.PartitionWriterProducerCallback
 
PASS_THROUGH_CONFIG_PREFIXES - Static variable in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
PATCH - com.linkedin.venice.authorization.Method
 
PATH_FILTER - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
ignore hdfs files with prefix "_" and "."
pathEquals(String) - Method in enum com.linkedin.venice.controllerapi.ControllerRoute
 
pathFor(ScatterGatherRequest<H, K>) - Method in class com.linkedin.alpini.router.api.Scatter
 
pathParser(ResourcePathParser<PATH, KEY>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
PATHPARSER_ATTRIBUTE_KEY - Static variable in class com.linkedin.venice.router.utils.VeniceRouterUtils
 
pathParserExtended(ExtendedResourcePathParser<PATH, KEY, HTTP_REQUEST>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
PathResourceRegistry<T> - Interface in com.linkedin.venice.utils
 
pause() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Pause the client on all subscriptions.
pause() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
pause(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
If the partitions were not previously subscribed, this method is a no-op.
pause(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Pauses message consumption for the specified PubSub topic-partition.
pause(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
pause(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Pause the client on all or subset of partitions this client is subscribed to.
pause(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
PAUSE - com.linkedin.davinci.kafka.consumer.ConsumerActionType
 
PAUSE_TRANSITION_FROM_STANDBY_TO_LEADER - com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
This partition is paused from follower to leader transition, to avoid two leaders in the process of store migration; so it's still running as a follower and won't switch to the leader role until the end of migration.
PauseStore - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
PauseStore() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
Default constructor.
PauseStore(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
All-args constructor.
payload - Variable in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
payloadUnion - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
This contains the main payload of the admin operation
payloadUnion - Variable in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
This contains the main payload of the message.
peek() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
peek() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
 
peek() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
peekFirst() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Retrieves, but does not remove, the first element of this list, or returns null if this list is empty.
peekLast() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Retrieves, but does not remove, the last element of this list, or returns null if this list is empty.
peekNextVersion() - Method in class com.linkedin.venice.meta.AbstractStore
 
peekNextVersion() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
peekNextVersion() - Method in interface com.linkedin.venice.meta.Store
 
peekNextVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
peekNextVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
peekNextVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
PendingConnectFuturePromise - Class in io.netty.bootstrap
The implementation of this method is mostly similar to DefaultChannelFuture except that we store the Channel inside a CompletableFuture because it is not yet known at the time of construction.
PendingConnectFuturePromise(Promise<Channel>) - Constructor for class io.netty.bootstrap.PendingConnectFuturePromise
 
PendingConnectPromise - Class in io.netty.bootstrap
The implementation of this method is mostly similar to DefaultChannelFuture except that we store the Channel inside a CompletableFuture because it is not yet known at the time of construction.
PendingConnectPromise(CompletableFuture<Channel>) - Constructor for class io.netty.bootstrap.PendingConnectPromise
 
PendingRequestThrottler - Class in com.linkedin.venice.router.throttle
This class maintains a simple counter for capacity management.
PendingRequestThrottler(long) - Constructor for class com.linkedin.venice.router.throttle.PendingRequestThrottler
 
PER_FIELD_TIMESTAMP - com.linkedin.venice.schema.rmd.RmdTimestampType
 
PerClusterInternalRTStoreInitializationRoutine - Class in com.linkedin.venice.controller.init
 
PerClusterInternalRTStoreInitializationRoutine(AvroProtocolDefinition, Function<String, String>, VeniceControllerMultiClusterConfig, Admin, Schema) - Constructor for class com.linkedin.venice.controller.init.PerClusterInternalRTStoreInitializationRoutine
 
perform(Set<String>, Command.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
Permission - Enum in com.linkedin.venice.authorization
A list of permission that will determine what Method a Principal can perform on a Resource.
PERSISTENCE_TYPE - Static variable in class com.linkedin.venice.ConfigKeys
 
PersistenceFailureException - Exception in com.linkedin.venice.exceptions
Thrown by the StorageEngine or Storage Partitions if storage fails
PersistenceFailureException() - Constructor for exception com.linkedin.venice.exceptions.PersistenceFailureException
 
PersistenceFailureException(String) - Constructor for exception com.linkedin.venice.exceptions.PersistenceFailureException
 
PersistenceFailureException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.PersistenceFailureException
 
PersistenceFailureException(Throwable) - Constructor for exception com.linkedin.venice.exceptions.PersistenceFailureException
 
persistenceType - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
persistenceType - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Type of persistence storage engine, and default is 'ROCKS_DB'
PersistenceType - Enum in com.linkedin.venice.meta
Enums of persistence types in Venice.
Persona - Class in com.linkedin.venice.persona
A class to represent a Persona, a relationship between stores and a quota system that is enforced.
Persona() - Constructor for class com.linkedin.venice.persona.Persona
 
Persona(Persona) - Constructor for class com.linkedin.venice.persona.Persona
 
Persona(String, long, Set<String>, Set<String>) - Constructor for class com.linkedin.venice.persona.Persona
 
PERSONA_DOES_NOT_EXIST_REGEX - Static variable in class com.linkedin.venice.utils.TestStoragePersonaUtils
 
PERSONA_NAME - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PERSONA_OWNERS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PERSONA_QUOTA - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PERSONA_STORES - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
personaContainsStore(String, String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
pickConsumerForPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
pickConsumerForPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.PartitionWiseKafkaConsumerService
 
pickConsumerForPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.TopicWiseKafkaConsumerService
This function will return a consumer for the passed StoreIngestionTask.
pid() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
 
PID - Static variable in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
PigzDeflateCompressor - Class in com.linkedin.alpini.io
 
PigzDeflateCompressor(PigzOutputStream, int, int) - Constructor for class com.linkedin.alpini.io.PigzDeflateCompressor
 
PigzOutputStream - Class in com.linkedin.alpini.io
 
PigzOutputStream(int, Executor, int, OutputStream) - Constructor for class com.linkedin.alpini.io.PigzOutputStream
Creates a new output stream with the specified compression level, concurrency and a default block size.
PigzOutputStream(int, Executor, int, OutputStream, int) - Constructor for class com.linkedin.alpini.io.PigzOutputStream
Creates a new output stream with the specified compression level, concurrency and block size.
PigzOutputStream(int, Executor, int, OutputStream, int, Function<PigzOutputStream, PigzOutputStream.Compressor>) - Constructor for class com.linkedin.alpini.io.PigzOutputStream
 
PigzOutputStream.Compressor - Class in com.linkedin.alpini.io
 
pingCallTracker() - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
pipelineFactory(Class<CHANNEL_HANDLER>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
pipelineFactory(Class<CHANNEL_HANDLER>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
planInputPartitions() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputScan
 
poll() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
poll() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Retrieves and removes the head (first element) of this list
poll() - Method in class com.linkedin.alpini.base.queuing.AbstractQOSBasedQueue
 
poll() - Method in class com.linkedin.alpini.base.queuing.QOSFCFSQueue
 
poll() - Method in interface com.linkedin.alpini.base.queuing.SimpleQueue
 
poll() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
poll(long) - Method in interface com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumer
polls for the next batch of change events.
poll(long) - Method in class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
poll(long) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Polling function to get any available messages from the underlying system for all partitions subscribed.
poll(long) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
poll(long) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
poll(long) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Polls the Kafka consumer for messages from the subscribed topic partitions within the specified time duration.
poll(long) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
poll(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
poll(long, TimeUnit) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
poll(PubSubConsumerAdapter, String, long) - Method in class com.linkedin.davinci.kafka.consumer.KafkaClusterBasedRecordThrottler
 
poll(InMemoryKafkaBroker, Map<PubSubTopicPartition, Long>, long) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.AbstractPollStrategy
 
poll(InMemoryKafkaBroker, Map<PubSubTopicPartition, Long>, long) - Method in interface com.linkedin.venice.unit.kafka.consumer.poll.PollStrategy
 
POLL_JOB_STATUS_INTERVAL_MS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
POLL_STATUS_RETRY_ATTEMPTS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
pollChannel() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Poll a Channel out of the internal storage to reuse it.
pollChannel() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Poll a Channel out of the internal storage to reuse it.
pollFirst() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Retrieves and removes the first element of this list, or returns null if this list is empty.
pollJobStatusIntervalMs - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
pollLast() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Retrieves and removes the last element of this list, or returns null if this list is empty.
PollStrategy - Interface in com.linkedin.venice.unit.kafka.consumer.poll
This interface is used inside of the MockInMemoryConsumer in order to mess around with the way messages are delivered to the consuming code.
pool - Variable in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
PoolChannelGroup(String) - Constructor for class com.linkedin.alpini.netty4.pool.FastFixedChannelPool.PoolChannelGroup
 
POOLED_ALLOCATOR - Static variable in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
poolSize - Variable in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
PoolStats - Interface in com.linkedin.alpini.base.pool
 
PoolStats.LifeCycleStats - Interface in com.linkedin.alpini.base.pool
 
pop() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Pops an element from the stack represented by this list.
PortableHttpResponse - Interface in com.linkedin.venice.router.httpclient
This interface exposes the commonalities between the Apache httpasyncclient and Netty and R2 client.
post(String, byte[]) - Method in class com.linkedin.venice.client.store.transport.TransportClient
 
post(String, Map<String, String>, byte[]) - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
post(String, Map<String, String>, byte[]) - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
Note: The callback that is triggered by CloseableHttpAsyncClient runs in the same thread as one of it's worker threads and if the users of the future run tasks that block the release of the future thread, a deadlock will occur.
post(String, Map<String, String>, byte[]) - Method in class com.linkedin.venice.client.store.transport.TransportClient
 
post(String, Map<String, String>, byte[]) - Method in class com.linkedin.venice.fastclient.transport.GrpcTransportClient
 
post(String, Map<String, String>, byte[]) - Method in class com.linkedin.venice.fastclient.transport.R2TransportClient
 
POST - com.linkedin.venice.authorization.Method
Datavault Restli Methods
POST - com.linkedin.venice.HttpMethod
 
postEndOfPushJob(String, String, VeniceProperties, PushJobDetailsStatus) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked when a job ends, either because it completed, had an error, or was killed (as indicated by the PushJobDetailsStatus parameter).

Cardinality: once per push job.
postSchemaRegistration(String, String, String, Map<Integer, String>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked after registering a new schema.

Cardinality: once per successful schema registration.
postStartOfPushJob(String, String, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked after starting a new job (i.e.
postStartOfStoreVersionIngestionForDaVinci(String, String, int, String, Lazy<JobStatusQueryResponse>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked after informing Da Vinci Clients that they may start to ingest a new store-version.

It is important to note that:

1.
postStoreVersionCreation(String, String, int, String, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked after creating a store-version in a given region, which means the following actions succeeded:

- All StoreLifecycleHooks.preStoreVersionCreation(String, String, int, String, Lazy, VeniceProperties) hooks.
- Creation of the store-version's dedicated resources (pub sub topic, Helix resource).
- Server replicas have begun ingesting.

Cardinality: once per successful store-version creation per region.
postStoreVersionLeaderReplication(String, String, int, String, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked after all leader replicas of a store-version within a single region have completed, which means the data replication to that region is done.

Cardinality: once per successfully-replicated store-version per region.
postStoreVersionSwap(String, String, int, String, Lazy<JobStatusQueryResponse>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked after swapping read traffic for servers.

Cardinality: once per store-version per region which has successfully swapped.
PR_SET_NAME - Static variable in interface com.linkedin.alpini.jna.ThreadUtils.LinuxCLib
 
prctl(int, String, long, long, long) - Method in interface com.linkedin.alpini.jna.ThreadUtils.LinuxCLib
 
preCheckDerivedSchemaAndGetNextAvailableId(String, int, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
preCheckDerivedSchemaAndGetNextAvailableId(String, int, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
preCheckDerivedSchemaAndGetNextAvailableId(String, int, String) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
 
preCheckValueSchemaAndGetNextAvailableId(String, String, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
Check if the incoming schema is a valid schema and return the next available schema ID.
preCheckValueSchemaAndGetNextAvailableId(String, String, DirectionalSchemaCompatibilityType) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
preCheckValueSchemaAndGetNextAvailableId(String, String, DirectionalSchemaCompatibilityType) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
 
Preconditions - Enum in com.linkedin.alpini.base.misc
Utility methods for precondition checks.
Predicate - Interface in com.linkedin.venice.client.store.predicate
Functor interface for performing a predicate test on GenericRecord
PredicateBuilder - Class in com.linkedin.venice.client.store.predicate
 
PredicateBuilder() - Constructor for class com.linkedin.venice.client.store.predicate.PredicateBuilder
 
preEndOfPushJob(String, String, Lazy<JobStatusQueryResponse>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked prior to ending a job.
prefetchAndCacheLatestOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Prefetch and cache the latest offset for the given topic-partition.
prefillAvroRecordWithDefaultValue(T) - Static method in class com.linkedin.venice.utils.AvroRecordUtils
This function is used to pre-fill the default value defined in schema.
PREPARE_DATA_RECOVERY - com.linkedin.venice.controllerapi.ControllerRoute
 
prepareDataRecovery(Admin) - Method in class com.linkedin.venice.controller.server.DataRecoveryRoutes
 
prepareDataRecovery(String, String, int, String, String, Optional<Integer>) - Method in interface com.linkedin.venice.controller.Admin
Prepare for data recovery in the destination fabric.
prepareDataRecovery(String, String, int, String, String, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
prepareDataRecovery(String, String, int, String, String, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
prepareDataRecovery(String, String, String, int, Optional<Integer>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
prepareForShutdown() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
prepareForShutdown() - Method in interface com.linkedin.davinci.ingestion.VeniceIngestionBackend
 
preparePartitionForReading(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
prepareRequest(BHS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
prepareRetry(AsyncFuture<H>, P, BHS, R, AsyncPromise<List<HR>>, AsyncFuture<Void>, Executor, HostHealthMonitor<H>, ScatterGatherStats.Delta, Metrics) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
prepareStoreVersionForDataRecovery(String, String, String, int, int) - Method in class com.linkedin.venice.controller.datarecovery.DataRecoveryManager
 
prepareUpgradeFrom(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Prepares to upgrade to another protocol from HTTP.
prepareVeniceWriter(String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreVeniceWriterCache
 
prependIntHeaderToByteBuffer(ByteBuffer, int, boolean) - Static method in class com.linkedin.venice.utils.ByteUtils
This function will return a ByteBuffer that has the integer prepended as a header from the current position.
preSchemaRegistration(String, String, String, Map<Integer, String>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked prior to registering a new schema, but after standard checks already succeeded.
preserveLastFew(VersionStatus) - Static method in enum com.linkedin.venice.meta.VersionStatus
For all the status which returns true, last few versions (few count, controlled by config) will be preserved.
preStartOfPushJob(String, String, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked prior to starting a new job.
preStartOfStoreVersionIngestionForDaVinci(String, String, int, String, Lazy<JobStatusQueryResponse>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked prior to informing Da Vinci Clients about starting to ingest a new store-version.

Cardinality: once per store-version per region.
preStoreVersionCreation(String, String, int, String, Lazy<JobStatusQueryResponse>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked prior to creating a store-version in a given region.

Cardinality: once per store-version creation attempt per region, assuming no previous failures.
preStoreVersionSwap(String, String, int, String, Lazy<JobStatusQueryResponse>, VeniceProperties) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked prior to swapping read traffic for servers.
prettyString() - Method in enum com.linkedin.davinci.ingestion.LagType
 
preventSystemExit() - Static method in class com.linkedin.venice.utils.TestUtils
 
previousStatuses - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
A map of string -> string which stands for previous PartitionStatus
previousValue - Variable in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
Principal - Class in com.linkedin.venice.authorization
Represents an actor entry.
Principal(String) - Constructor for class com.linkedin.venice.authorization.Principal
 
PRINCIPAL - com.linkedin.venice.Arg
 
printClasspath() - Static method in class com.linkedin.venice.utils.ReflectUtils
Print to the logs the entire classpath (one line per jar)
printf(Level, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
printf(Level, Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
printJarContainingBadClass(NoSuchMethodError) - Static method in class com.linkedin.venice.utils.ReflectUtils
Given an exception about a class that doesn't have the expected API, print to the logs which jar is that class coming from.
printObject(Object, Consumer<String>) - Static method in class com.linkedin.venice.AdminTool
 
privilegedCallable(Callable<T>) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a Callable object that will, when called, execute the given callable under the current access control context.
privilegedCallableUsingCurrentClassLoader(Callable<T>) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a Callable object that will, when called, execute the given callable under the current access control context, with the current context class loader as the context class loader.
privilegedThreadFactory() - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns a thread factory used to create new threads that have the same permissions as the current thread.
PROCEED - com.linkedin.venice.hooks.StoreLifecycleEventOutcome
 
PROCEED - com.linkedin.venice.hooks.StoreVersionLifecycleEventOutcome
Proceed, as if the hook did not exist.
process(KafkaInputMapperKey, KafkaInputMapperValue, AtomicReference<byte[]>, AtomicReference<byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
 
process(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcRequestProcessor
 
process(INPUT_KEY, INPUT_VALUE, AtomicReference<byte[]>, AtomicReference<byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
This function will return true if the input key/value pair is valid.
PROCESS_SHUTDOWN_COMMAND - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode various kinds of ingestion task commands, which are used to control ingestion task in child process.
processAndExtractLevelFromForkedProcessLog(ForkedJavaProcess.LogInfo, String) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
 
processBuilder() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
processCommonConsumerAction(ConsumerAction) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
processComputeResponses(List<FullHttpResponse>, String, Optional<Map<CharSequence, String>>) - Method in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
processConsumerAction(ConsumerAction, Store) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
processConsumerAction(ConsumerAction, Store) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
processConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This function will be invoked in StoreBufferService to process buffered PubSubMessage.
processControlMessage(ControlMessage, int, PartitionConsumptionState, int) - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
 
processControlMessage(ControlMessage, int, PartitionConsumptionState, int) - Method in class com.linkedin.davinci.store.view.VeniceViewWriter
Called when the server encounters a control message.
processData() - Method in class com.linkedin.venice.datarecovery.DataRecoveryEstimator
 
processData() - Method in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
processedRecordSizeSinceLastSync - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
How much bytes have been processed since last sync
processEndOfIncrementalPush(ControlMessage, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
processEndOfPush(KafkaMessageEnvelope, int, long, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
PROCESSING - com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
 
processInput(int, Reporter) - Method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
1.
processMessageAndMaybeProduceToKafka(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
processMessageAndMaybeProduceToKafka(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
processMultiGetResponseForStreaming(CompressionStrategy, ByteBuf) - Method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
 
processMultiGetResponses(List<FullHttpResponse>, String, int, Optional<Map<CharSequence, String>>) - Method in class com.linkedin.venice.router.api.VeniceResponseAggregator
If a part of a multi-get request fails, the entire request should fail from the client's perspective.
processRecord(INPUT_KEY, INPUT_VALUE, BiConsumer<byte[], byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
 
processRecord(ByteBuffer, ByteBuffer, byte[], int, int, int, GenericRecord) - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
 
processRecord(ByteBuffer, ByteBuffer, byte[], int, int, int, GenericRecord) - Method in class com.linkedin.davinci.store.view.VeniceViewWriter
To be called as a given ingestion task consumes each record.
processRecord(Row) - Method in class com.linkedin.venice.hadoop.spark.datawriter.recordprocessor.SparkInputRecordProcessor
 
processRecordBytes(ByteBuffer, T, byte[], ByteBuffer, PubSubTopicPartition, int, long) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
processRequest(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.GrpcOutboundResponseHandler
 
processRequest(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.GrpcOutboundStatsHandler
 
processRequest(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.GrpcReadQuotaEnforcementHandler
 
processRequest(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.GrpcRouterRequestHandler
 
processRequest(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.GrpcStatsHandler
 
processRequest(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.GrpcStorageReadRequestHandler
 
processRequest(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
 
ProcessShutdownCommand - Class in com.linkedin.venice.ingestion.protocol
 
ProcessShutdownCommand() - Constructor for class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
Default constructor.
ProcessShutdownCommand(Integer) - Constructor for class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
All-args constructor.
processStartOfIncrementalPush(ControlMessage, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
processTopicSwitch(ControlMessage, int, long, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
Process TopicSwitch control message at given partition offset for a specific PartitionConsumptionState.
processTopicSwitch(ControlMessage, int, long, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
Process TopicSwitch control message at given partition offset for a specific PartitionConsumptionState.
processTopicSwitch(ControlMessage, int, long, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
ProcessUtil - Enum in com.linkedin.alpini.base.misc
Utility methods for Processes.
processValuesForKey(byte[], Iterator<byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
processVersionSwapMessage(ControlMessage, int, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
processVersionSwapMessage(ControlMessage, int, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This isn't really used for ingestion outside of A/A, so we NoOp here and rely on the actual implementation in ActiveActiveStoreIngestionTask
produce(String, int, InMemoryKafkaMessage) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
 
PRODUCED_TO_KAFKA - com.linkedin.davinci.kafka.consumer.StoreIngestionTask.DelegateConsumerRecordResult
The consumer record has been produced to local version topic by leader.
produceMessages(PubSubProducerAdapter, PubSubTopicPartition, int, long, boolean) - Static method in class com.linkedin.venice.utils.PubSubHelper
 
PRODUCER_CALLBACK_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
producerConfigs - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
producerGUID - Variable in class com.linkedin.venice.kafka.protocol.ProducerMetadata
A unique identifier for this producer.
producerGUID - Variable in class com.linkedin.venice.storage.protocol.ChunkId
The GUID belonging to the producer of this value.
producerMetadata - Variable in class com.linkedin.venice.DumpAdminMessages.AdminOperationInfo
 
producerMetadata - Variable in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
ProducerMetadata contains information that the consumer can use to identify an upstream producer.
ProducerMetadata - Class in com.linkedin.venice.kafka.protocol
 
ProducerMetadata() - Constructor for class com.linkedin.venice.kafka.protocol.ProducerMetadata
Default constructor.
ProducerMetadata(GUID, Integer, Integer, Long, Long) - Constructor for class com.linkedin.venice.kafka.protocol.ProducerMetadata
All-args constructor.
ProducerPartitionState - Class in com.linkedin.venice.kafka.protocol.state
A record containing the state pertaining to the data sent by one upstream producer into one partition.
ProducerPartitionState() - Constructor for class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Default constructor.
ProducerPartitionState(Integer, Integer, Boolean, Integer, Long, Integer, ByteBuffer, Map<CharSequence, Long>, Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
All-args constructor.
producerStates - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
A map of producer GUID -> producer state.
producerTimestampLagThresholdToGoOnlineInSeconds - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
producerTimestampLagThresholdToGoOnlineInSeconds - Variable in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
producerTimestampLagThresholdToGoOnlineInSeconds - Variable in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
ProducerTool - Class in com.linkedin.venice.producer.online
 
ProducerTool() - Constructor for class com.linkedin.venice.producer.online.ProducerTool
 
produceToLocalKafka(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, LeaderProducedRecordContext, BiConsumer<ChunkAwareCallback, LeaderMetadataWrapper>, int, String, int, long) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
produceToLocalKafka(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState, LeaderProducedRecordContext, BiConsumer<ChunkAwareCallback, LeaderMetadataWrapper>, int, String, int, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
produceToStoreBufferService(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, LeaderProducedRecordContext, int, String, long, long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This function will produce a pair of consumer record and a it's derived produced record to the writer buffers maintained by StoreBufferService.
produceToStoreBufferServiceOrKafka(Iterable<PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>>, PubSubTopicPartition, String, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This function is in charge of producing the consumer records to the writer buffers maintained by StoreBufferService.
progress(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Periodic progress report of consumption for a store and partition.
progress(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
progress(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
progress(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
progress(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
PROGRESS - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
PROGRESS - com.linkedin.venice.pushmonitor.ExecutionStatus
Task is processing data.
PROGRESS - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
PROGRESS_COMPLETED - Static variable in interface com.linkedin.venice.hadoop.task.TaskTracker
 
PROGRESS_INTERVAL - com.linkedin.venice.Arg
 
PROGRESS_NOT_SUPPORTED - Static variable in interface com.linkedin.venice.hadoop.task.TaskTracker
 
project(String...) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
project(String...) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Setup project fields, and right now only top-level fields are supported.
project(Collection<String>) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
project(Collection<String>) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Setup project fields, and right now only top-level fields are supported.
PROJECTION_SPEC - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
projectionType(String...) - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
Get the type created by selecting only a subset of properties from this type.
PromiseDelegate<V> - Class in com.linkedin.alpini.base.misc
A simple delegate class which wraps an existing Promise and permits overriding of some of its methods.
PromiseDelegate(Promise<V>) - Constructor for class com.linkedin.alpini.base.misc.PromiseDelegate
 
PROMOTE_TO_LEADER - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
promoteToLeader(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
promoteToLeader(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
promoteToLeader(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in interface com.linkedin.davinci.ingestion.VeniceIngestionBackend
 
promoteToLeader(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
promoteToLeader(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
 
promoteToLeader(PubSubTopicPartition, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
promoteToLeader(PubSubTopicPartition, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
promoteToLeader(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
PropertyBuilder - Class in com.linkedin.venice.utils
PropertyBuilder is the suggested Way to construct VeniceProperties.
PropertyBuilder() - Constructor for class com.linkedin.venice.utils.PropertyBuilder
 
props - Variable in class com.linkedin.venice.partitioner.VenicePartitioner
 
props - Variable in class com.linkedin.venice.views.VeniceView
 
provider(BasicRequest) - Method in interface com.linkedin.alpini.router.api.MetricsProvider
 
PROVIDER_CLASS_NAME - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
pthread_setname_np(String) - Method in interface com.linkedin.alpini.jna.ThreadUtils.DarwinCLib
 
PUB_SUB_ADMIN_ADAPTER_FACTORY_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
 
PUB_SUB_CONSUMER_ADAPTER_FACTORY_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
 
PUB_SUB_PRODUCER_ADAPTER_FACTORY_CLASS - Static variable in class com.linkedin.venice.ConfigKeys
 
publishTimeStamp - Variable in class com.linkedin.venice.DumpAdminMessages.AdminOperationInfo
 
PUBSUB_ADMIN_API_DEFAULT_TIMEOUT_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_ADMIN_API_DEFAULT_TIMEOUT_MS_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_ADMIN_GET_TOPIC_CONFIG_RETRY_IN_SECONDS_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_API_DEFAULT_TIMEOUT_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_API_DEFAULT_TIMEOUT_MS_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_CHECK_TOPIC_EXISTENCE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_CHECK_TOPIC_EXISTENCE_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_POLL_RETRY_BACKOFF_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_POLL_RETRY_BACKOFF_MS_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_POLL_RETRY_TIMES - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_POLL_RETRY_TIMES_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_POLLING_FOR_METADATA_RETRY_MAX_ATTEMPT - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_POSITION_RESET_STRATEGY - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_POSITION_RESET_STRATEGY_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_TOPIC_QUERY_RETRY_INTERVAL_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_TOPIC_QUERY_RETRY_INTERVAL_MS_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_TOPIC_QUERY_RETRY_TIMES - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_CONSUMER_TOPIC_QUERY_RETRY_TIMES_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_FAST_OPERATION_TIMEOUT_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_NO_PRODUCER_TIME_IN_EMPTY_TOPIC_PARTITION - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_OFFSET_API_TIMEOUT_DURATION_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_OPERATION_TIMEOUT_MS_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_POSITION_WIRE_FORMAT - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode the position of a PubSub message.
PUBSUB_PRODUCER_USE_HIGH_THROUGHPUT_DEFAULTS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_TOPIC_DELETE_RETRY_TIMES - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_TOPIC_DELETION_STATUS_POLL_INTERVAL_MS_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
Default value of sleep interval for polling topic deletion status from ZK.
PUBSUB_TOPIC_MANAGER_METADATA_FETCHER_CONSUMER_POOL_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Number of PubSub consumer clients to be used per topic manager for fetching metadata.
PUBSUB_TOPIC_MANAGER_METADATA_FETCHER_CONSUMER_POOL_SIZE_DEFAULT_VALUE - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PUBSUB_TOPIC_MANAGER_METADATA_FETCHER_THREAD_POOL_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
The size of the per topic manager thread pool for fetching metadata asynchronously.
PUBSUB_TOPIC_UNKNOWN_RETENTION - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
 
PubSubAdminAdapter - Interface in com.linkedin.venice.pubsub.api
An adapter for PubSubAdmin to create/delete/list/update topics.
PubSubAdminAdapterFactory<ADAPTER extends PubSubAdminAdapter> - Interface in com.linkedin.venice.pubsub
Generic admin factory interface.
PubSubClientException - Exception in com.linkedin.venice.pubsub.api.exceptions
 
PubSubClientException(String) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubClientException
 
PubSubClientException(String, Throwable) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubClientException
 
PubSubClientRetriableException - Exception in com.linkedin.venice.pubsub.api.exceptions
 
PubSubClientRetriableException(String) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubClientRetriableException
 
PubSubClientRetriableException(String, Throwable) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubClientRetriableException
 
PubSubClientsFactory - Class in com.linkedin.venice.pubsub
A wrapper around pub-sub producer, consumer, and admin adapter factories This will be passed as one of the arguments to the component which depends on the pub-sub APIs.
PubSubClientsFactory(PubSubProducerAdapterFactory, PubSubConsumerAdapterFactory, PubSubAdminAdapterFactory) - Constructor for class com.linkedin.venice.pubsub.PubSubClientsFactory
 
PubSubClientsFactory(VeniceProperties) - Constructor for class com.linkedin.venice.pubsub.PubSubClientsFactory
 
PubSubConstants - Class in com.linkedin.venice.pubsub
Constants used by pub-sub components.
PubSubConstants() - Constructor for class com.linkedin.venice.pubsub.PubSubConstants
 
pubSubConsumer - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
PubSubConsumerAdapter - Interface in com.linkedin.venice.pubsub.api
An adapter for consuming messages from a Pub-Sub topic.
PubSubConsumerAdapterFactory<ADAPTER extends PubSubConsumerAdapter> - Interface in com.linkedin.venice.pubsub
Generic consumer factory interface.
PubSubHelper - Class in com.linkedin.venice.utils
 
PubSubHelper() - Constructor for class com.linkedin.venice.utils.PubSubHelper
 
PubSubHelper.MutablePubSubMessage - Class in com.linkedin.venice.utils
 
PubSubMessage<K,​V,​OFFSET> - Interface in com.linkedin.venice.pubsub.api
 
PubSubMessageDeserializer - Class in com.linkedin.venice.pubsub.api
The class for deserializing messages from the pubsub specific message format to PubSubMessage
PubSubMessageDeserializer(KafkaValueSerializer, ObjectPool<KafkaMessageEnvelope>, ObjectPool<KafkaMessageEnvelope>) - Constructor for class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
 
PubSubMessageHeader - Class in com.linkedin.venice.pubsub.api
A key-value pair that is associated with a message
PubSubMessageHeader(String, byte[]) - Constructor for class com.linkedin.venice.pubsub.api.PubSubMessageHeader
 
PubSubMessageHeaders - Class in com.linkedin.venice.pubsub.api
Set of key-value pairs to tagged with messages produced to a topic.
PubSubMessageHeaders() - Constructor for class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
 
PubSubOpTimeoutException - Exception in com.linkedin.venice.pubsub.api.exceptions
Used when an operation against PubSub failed to complete in time.
PubSubOpTimeoutException(String) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubOpTimeoutException
 
PubSubOpTimeoutException(String, Throwable) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubOpTimeoutException
 
PubSubPosition - Interface in com.linkedin.venice.pubsub.api
Represents a position of a message in a partition of a topic.
PubSubPositionFactory - Class in com.linkedin.venice.pubsub
Factory class for creating PubSubPosition objects from wire format
PubSubPositionFactory() - Constructor for class com.linkedin.venice.pubsub.PubSubPositionFactory
 
PubSubPositionType - Class in com.linkedin.venice.pubsub
Constants for the different types of positions Do not change the values of these constants.
PubSubPositionType() - Constructor for class com.linkedin.venice.pubsub.PubSubPositionType
 
PubSubPositionWireFormat - Class in com.linkedin.venice.pubsub.api
 
PubSubPositionWireFormat() - Constructor for class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
Default constructor.
PubSubPositionWireFormat(Integer, ByteBuffer) - Constructor for class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
All-args constructor.
PubSubProducerAdapter - Interface in com.linkedin.venice.pubsub.api
The pub-sub producer interface with which venice writer's interact to send messages to pub-sub topic.
PubSubProducerAdapterFactory<ADAPTER extends PubSubProducerAdapter> - Interface in com.linkedin.venice.pubsub
Generic producer factory interface.
PubSubProducerCallback - Interface in com.linkedin.venice.pubsub.api
A callback interface that users of PubSubProducerAdapter should implement if they want to execute some code once PubSubProducerAdapter#sendMessage request is completed.
PubSubProducerCallbackSimpleImpl - Class in com.linkedin.venice.pubsub.adapter
A simple implementation of PubSubProducerCallback interface for testing purposes.
PubSubProducerCallbackSimpleImpl() - Constructor for class com.linkedin.venice.pubsub.adapter.PubSubProducerCallbackSimpleImpl
 
PubSubProduceResult - Interface in com.linkedin.venice.pubsub.api
An interface implemented by specific PubSubProducerAdapters to return the result of a produce action.
PubSubTopic - Interface in com.linkedin.venice.pubsub.api
 
PubSubTopicAuthorizationException - Exception in com.linkedin.venice.pubsub.api.exceptions
Class for all Venice exceptions that are triggered by Kafka topic authorization related issues.
PubSubTopicAuthorizationException(String) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicAuthorizationException
 
PubSubTopicAuthorizationException(String, Throwable) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicAuthorizationException
 
PubSubTopicConfigResponse - Class in com.linkedin.venice.controllerapi
 
PubSubTopicConfigResponse() - Constructor for class com.linkedin.venice.controllerapi.PubSubTopicConfigResponse
 
PubSubTopicConfiguration - Class in com.linkedin.venice.pubsub
Represents a PubSubTopic configuration.
PubSubTopicConfiguration(Optional<Long>, boolean, Optional<Integer>, Long, Optional<Long>) - Constructor for class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
PubSubTopicDoesNotExistException - Exception in com.linkedin.venice.pubsub.api.exceptions
The source or destination topic for the replication request does not exit
PubSubTopicDoesNotExistException(PubSubTopic) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicDoesNotExistException
 
PubSubTopicDoesNotExistException(PubSubTopic, Throwable) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicDoesNotExistException
 
PubSubTopicDoesNotExistException(String) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicDoesNotExistException
 
PubSubTopicDoesNotExistException(String, Throwable) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicDoesNotExistException
 
PubSubTopicExistsException - Exception in com.linkedin.venice.pubsub.api.exceptions
 
PubSubTopicExistsException(PubSubTopic, Throwable) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicExistsException
 
PubSubTopicExistsException(String) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubTopicExistsException
 
PubSubTopicImpl - Class in com.linkedin.venice.pubsub
 
PubSubTopicPartition - Interface in com.linkedin.venice.pubsub.api
 
PubSubTopicPartitionImpl - Class in com.linkedin.venice.pubsub
 
PubSubTopicPartitionImpl(PubSubTopic, int) - Constructor for class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
 
PubSubTopicPartitionInfo - Class in com.linkedin.venice.pubsub
 
PubSubTopicPartitionInfo(PubSubTopic, int, Boolean) - Constructor for class com.linkedin.venice.pubsub.PubSubTopicPartitionInfo
 
PubSubTopicPartitionOffset - Class in com.linkedin.venice.unit.kafka.consumer.poll
 
PubSubTopicPartitionOffset(PubSubTopicPartition, Long) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
 
pubSubTopicRepository - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
pubSubTopicRepository - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
pubSubTopicRepository - Variable in class com.linkedin.venice.controller.VeniceHelixAdmin
 
PubSubTopicRepository - Class in com.linkedin.venice.pubsub
 
PubSubTopicRepository() - Constructor for class com.linkedin.venice.pubsub.PubSubTopicRepository
 
PubSubTopicType - Enum in com.linkedin.venice.pubsub.api
 
PubSubUnsubscribedTopicPartitionException - Exception in com.linkedin.venice.pubsub.api.exceptions
 
PubSubUnsubscribedTopicPartitionException(PubSubTopicPartition) - Constructor for exception com.linkedin.venice.pubsub.api.exceptions.PubSubUnsubscribedTopicPartitionException
 
push(E) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Pushes an element onto the stack represented by this list.
PUSH_ID - com.linkedin.venice.Arg
 
PUSH_IN_SORTED_ORDER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSH_JOB_DETAILS - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to encode push job details records to be written to the PushJobDetails system store.
PUSH_JOB_DETAILS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSH_JOB_DETAILS_STORE - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
PUSH_JOB_DURATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSH_JOB_GUID_LEAST_SIGNIFICANT_BITS - Static variable in class com.linkedin.venice.ConfigKeys
The least-significant-bits of the producer GUID used by VenicePushJob encoded as a long.
PUSH_JOB_GUID_MOST_SIGNIFICANT_BITS - Static variable in class com.linkedin.venice.ConfigKeys
The most-significant-bits of the producer GUID used by VenicePushJob encoded as a long.
PUSH_JOB_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSH_JOB_STATUS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSH_JOB_STATUS_STORE_CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
The name of the cluster that the internal store for storing push job details records belongs to.
PUSH_JOB_STATUS_UPLOAD_ENABLE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config to enable the service that uploads push job statuses to the controller using ControllerClient.uploadPushJobStatus(), the job status is then packaged and sent to dedicated Kafka channel.
PUSH_MONITOR_TYPE - Static variable in class com.linkedin.venice.ConfigKeys
Flag to indicate which push monitor controller will pick up for an upcoming push
PUSH_SSL_ALLOWLIST - Static variable in class com.linkedin.venice.ConfigKeys
Allowlist of stores which are allowed to push data with SSL.
PUSH_SSL_WHITELIST - Static variable in class com.linkedin.venice.ConfigKeys
Deprecated.
PUSH_STATUS_INSTANCE_NAME_SUFFIX - Static variable in class com.linkedin.venice.ConfigKeys
Config to control what's the suffix for Da Vinci instance which is reporting push status and heartbeats.
PUSH_STATUS_STORE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Config to control if push status store is enabled and should be initialized
PUSH_STATUS_STORE_HEARTBEAT_EXPIRATION_TIME_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
The expiration timeout.
PUSH_STATUS_STORE_HEARTBEAT_INTERVAL_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Interval for Da Vinci clients to send heartbeats.
PUSH_STATUS_SYSTEM_SCHEMA_STORE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Value schema for push status system store.
PUSH_STATUS_SYSTEM_SCHEMA_STORE_KEY - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Key schema for push status system store.
PUSH_STATUS_SYSTEM_STORE_AUTO_CREATION_VALIDATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
PUSH_STRATEGY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSH_STREAM_SOURCE_ADDRESS - com.linkedin.venice.Arg
 
PUSH_STREAM_SOURCE_ADDRESS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSH_TYPE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
PUSHED - com.linkedin.venice.meta.VersionStatus
 
PushHealthStats - Class in com.linkedin.venice.pushmonitor
 
PushHealthStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.pushmonitor.PushHealthStats
 
pushId - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
PushInputSchemaBuilder - Class in com.linkedin.venice.utils
This class is a simple schema builder to generate Venice Push Job input file schema.
PushInputSchemaBuilder() - Constructor for class com.linkedin.venice.utils.PushInputSchemaBuilder
 
pushJobConfigs - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
PushJobDetails - Class in com.linkedin.venice.status.protocol
 
PushJobDetails() - Constructor for class com.linkedin.venice.status.protocol.PushJobDetails
Default constructor.
PushJobDetails(CharSequence, Long, List<PushJobDetailsStatusTuple>, Map<CharSequence, List<PushJobDetailsStatusTuple>>, CharSequence, Integer, Integer, Boolean, Long, Long, Long, Long, Long, Long, Long, Map<CharSequence, CharSequence>, Map<CharSequence, CharSequence>, Integer, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.status.protocol.PushJobDetails
All-args constructor.
PushJobDetailsStatus - Enum in com.linkedin.venice.status
 
PushJobDetailsStatusTuple - Class in com.linkedin.venice.status.protocol
0 => STARTED, 1 => COMPLETED, 2 => ERROR, 3 => NOT_CREATED, 4 => UNKNOWN, 5 => TOPIC_CREATED, 6 => WRITE_TO_KAFKA_COMPLETED, 7 => KILLED, 8 => END_OF_PUSH_RECEIVED, 9 => START_OF_INCREMENTAL_PUSH_RECEIVED, 10 => END_OF_INCREMENTAL_PUSH_RECEIVED
PushJobDetailsStatusTuple() - Constructor for class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
Default constructor.
PushJobDetailsStatusTuple(Integer, Long) - Constructor for class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
All-args constructor.
PushJobHeartbeatSender - Interface in com.linkedin.venice.hadoop.heartbeat
This interface provides methods to send push job heartbeats
PushJobHeartbeatSenderFactory - Interface in com.linkedin.venice.hadoop.heartbeat
This interface provides methods to let users create a heartbeat provider
pushJobId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
pushJobId - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
pushJobId - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
pushJobLatestCheckpoint - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
Latest checkpoint reached by the push job if available, negative values are known error checkpoints.
pushJobSetting - Variable in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
PushJobSetting - Class in com.linkedin.venice.hadoop
This class carries the state for the duration of the VenicePushJob.
PushJobSetting() - Constructor for class com.linkedin.venice.hadoop.PushJobSetting
 
PushJobStatus - Enum in com.linkedin.venice.status.protocol.enums
 
PushJobStatusRecordKey - Class in com.linkedin.venice.status.protocol
 
PushJobStatusRecordKey() - Constructor for class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
Default constructor.
PushJobStatusRecordKey(CharSequence, Integer) - Constructor for class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
All-args constructor.
PushJobStatusUploadResponse - Class in com.linkedin.venice.controllerapi.routes
Response for uploading a job status record.
PushJobStatusUploadResponse() - Constructor for class com.linkedin.venice.controllerapi.routes.PushJobStatusUploadResponse
 
pushJobZstdConfig - Variable in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
PushJobZstdConfig - Class in com.linkedin.venice.hadoop
 
PushJobZstdConfig(VeniceProperties, int) - Constructor for class com.linkedin.venice.hadoop.PushJobZstdConfig
 
PushMonitor - Interface in com.linkedin.venice.pushmonitor
In Venice, Push is a task that asynchronously writes data to Venice.
PushMonitorDelegator - Class in com.linkedin.venice.pushmonitor
This class maintains the mapping of Kafka topic to each PushMonitor instance and delegates calls to the correct instance.
PushMonitorDelegator(String, RoutingDataRepository, OfflinePushAccessor, StoreCleaner, ReadWriteStoreRepository, AggPushHealthStats, RealTimeTopicSwitcher, ClusterLockManager, String, List<String>, HelixAdminClient, VeniceControllerConfig, PushStatusStoreReader, DisabledPartitionStats) - Constructor for class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
PushMonitorType - Enum in com.linkedin.venice.pushmonitor
This enum controls the behavior of how PushMonitorDelegator chooses proper PushMonitor for resources.
PushMonitorUtils - Class in com.linkedin.venice.pushmonitor
This class contains some common util methods for push monitoring purpose.
PushMonitorUtils() - Constructor for class com.linkedin.venice.pushmonitor.PushMonitorUtils
 
PushStatusCleanUpServiceState - Enum in com.linkedin.venice.pushmonitor
 
PushStatusCleanUpStats - Class in com.linkedin.venice.pushmonitor
 
PushStatusCleanUpStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.pushmonitor.PushStatusCleanUpStats
 
PushStatusCollector - Class in com.linkedin.venice.pushmonitor
This class serves as a collector of offline push status for both Venice Server and Da Vinci clients.
PushStatusCollector(ReadWriteStoreRepository, PushStatusStoreReader, Consumer<String>, BiConsumer<String, ExecutionStatusWithDetails>, boolean, int, int, int, int, double, boolean) - Constructor for class com.linkedin.venice.pushmonitor.PushStatusCollector
 
PushStatusDecider - Class in com.linkedin.venice.pushmonitor
Decide the offline push status by checking all replicas statuses under different offline push strategies.
PushStatusDecider() - Constructor for class com.linkedin.venice.pushmonitor.PushStatusDecider
 
PushStatusKey - Class in com.linkedin.venice.pushstatus
 
PushStatusKey() - Constructor for class com.linkedin.venice.pushstatus.PushStatusKey
Default constructor.
PushStatusKey(List<Object>, Integer) - Constructor for class com.linkedin.venice.pushstatus.PushStatusKey
All-args constructor.
PushStatusNotifier - Class in com.linkedin.davinci.notifier
Notifies both OfflinePushStatus and Helix Customized View
PushStatusNotifier(OfflinePushAccessor, HelixPartitionStatusAccessor, PushStatusStoreWriter, ReadOnlyStoreRepository, String) - Constructor for class com.linkedin.davinci.notifier.PushStatusNotifier
 
PushStatusResponse - Class in com.linkedin.venice.routerapi
Push job status response for a resource; this is a response that will be returned by Router.
PushStatusResponse() - Constructor for class com.linkedin.venice.routerapi.PushStatusResponse
 
PushStatusStoreReader - Class in com.linkedin.venice.pushstatushelper
This class is a helper class for Venice controller to read PushStatus / Heartbeat messages.
PushStatusStoreReader(D2Client, String, long) - Constructor for class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
 
PushStatusStoreUtils - Class in com.linkedin.venice.common
Helper class for PushStatusStore related logic.
PushStatusStoreUtils() - Constructor for class com.linkedin.venice.common.PushStatusStoreUtils
 
PushStatusStoreUtils.PushStatusKeyType - Enum in com.linkedin.venice.common
 
PushStatusStoreVeniceWriterCache - Class in com.linkedin.venice.pushstatushelper
Wrapper class for acquiring VeniceWriter for push status stores.
PushStatusStoreVeniceWriterCache(VeniceWriterFactory, Schema, Schema) - Constructor for class com.linkedin.venice.pushstatushelper.PushStatusStoreVeniceWriterCache
 
PushStatusStoreWriter - Class in com.linkedin.venice.pushstatushelper
PushStatusStoreWriter is a helper class for Da Vinci to write PushStatus and heartbeat message into PushStatus store real-time topic.
PushStatusStoreWriter(VeniceWriterFactory, String, SchemaEntry, DerivedSchemaEntry) - Constructor for class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
PushStatusSystemStoreAutoCreationValidation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
PushStatusSystemStoreAutoCreationValidation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
Default constructor.
PushStatusSystemStoreAutoCreationValidation(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
All-args constructor.
PushStatusValue - Class in com.linkedin.venice.pushstatus
 
PushStatusValue() - Constructor for class com.linkedin.venice.pushstatus.PushStatusValue
Default constructor.
PushStatusValue(Map<CharSequence, Integer>, Long) - Constructor for class com.linkedin.venice.pushstatus.PushStatusValue
All-args constructor.
pushStreamSourceAddress - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
pushStreamSourceAddress - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
pushStreamSourceAddress - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
pushStreamSourceAddress - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
pushStreamSourceAddress - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Address to the kafka broker which holds the source of truth topic for this store version.
pushStreamSourceAddress - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Address to the kafka broker which holds the source of truth topic for this store version.
pushType - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
The push type of the new version, 0 => BATCH, 1 => STREAM_REPROCESSING.
pushType - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
pushType - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Producer type for this version, and default is 'BATCH'
put() - Method in class com.linkedin.venice.router.throttle.PendingRequestThrottler
When the incoming PendingRequestThrottler.put() exceeds the pre-defined counter, 'false' will be returned.
put(byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Puts a value into the partition database
put(byte[], byte[]) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
put(byte[], byte[]) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
put(byte[], byte[]) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
put(byte[], byte[]) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
put(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
put(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
put(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
put(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
put(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
put(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
put(int, byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
put(int, byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
put(int, Object) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
put(int, Object) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
put(int, Object) - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
put(int, Object) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
put(int, Object) - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
put(int, Object) - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
 
put(int, Object) - Method in class com.linkedin.venice.client.store.schemas.TestKeyRecord
 
put(int, Object) - Method in class com.linkedin.venice.client.store.schemas.TestValueRecord
 
put(int, Object) - Method in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
put(int, Object) - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.Count
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
put(int, Object) - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
put(int, Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
put(int, Object) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
put(int, Object) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
put(int, Object) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
put(int, Object) - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
put(int, Object) - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
put(int, Object) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
put(int, Object) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
put(int, Object) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
put(int, Object) - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
put(int, Object) - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.Delete
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.Put
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.Update
 
put(int, Object) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
put(int, Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
put(int, Object) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
put(int, Object) - Method in class com.linkedin.venice.metadata.response.VersionProperties
 
put(int, Object) - Method in class com.linkedin.venice.participant.protocol.KillPushJob
 
put(int, Object) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
put(int, Object) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
put(int, Object) - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
put(int, Object) - Method in class com.linkedin.venice.pushstatus.PushStatusKey
 
put(int, Object) - Method in class com.linkedin.venice.pushstatus.PushStatusValue
 
put(int, Object) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
put(int, Object) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
put(int, Object) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
put(int, Object) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
put(int, Object) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
put(int, Object) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
 
put(int, Object) - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
put(int, Object) - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
put(int, Object) - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
put(int, Object) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
put(int, Object) - Method in class com.linkedin.venice.storage.protocol.ChunkId
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
put(int, Object) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
put(int, K, V) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
put(ValueAndRmd<ByteBuffer>, ByteBuffer, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeByteBuffer
 
put(ValueAndRmd<GenericRecord>, GenericRecord, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeGenericRecord
Three important requirements regarding input params: 1.
put(ValueAndRmd<T>, T, long, int, long, int) - Method in interface com.linkedin.davinci.replication.merge.Merge
 
put(KafkaKey, KafkaMessageEnvelope, PubSubProducerCallback, int, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
Deprecated.
put(Lazy<ByteBuffer>, RmdWithValueSchemaId, ByteBuffer, long, int, long, int, int) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolver
Perform conflict resolution when the incoming operation is a PUT operation.
put(Lazy<K>, Lazy<V>) - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
 
put(E) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
put(File) - Method in class com.linkedin.venice.utils.PropertyBuilder
 
put(Object, Object) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
put(String, int, OffsetRecord) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
put(String, int, OffsetRecord) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
put(String, int, OffsetRecord) - Method in class com.linkedin.venice.offsets.DeepCopyOffsetManager
 
put(String, int, OffsetRecord) - Method in class com.linkedin.venice.offsets.InMemoryOffsetManager
 
put(String, int, OffsetRecord) - Method in interface com.linkedin.venice.offsets.OffsetManager
Records the offset with underlying/external storage.
put(String, Object) - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
 
put(String, Object) - Method in class com.linkedin.venice.utils.PropertyBuilder
 
put(Properties) - Method in class com.linkedin.venice.utils.PropertyBuilder
 
put(K, V) - Method in class com.linkedin.alpini.base.misc.ArrayMap
put(K, V) - Method in class com.linkedin.alpini.base.misc.CollectionUtil.MapBuilder
 
put(K, V) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
put(K, V) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
put(K, V) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
put(K, V) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
put(K, V) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
put(K, V) - Method in class com.linkedin.davinci.utils.IndexedHashMap
Associates the specified value with the specified key in this map.
put(K, V, int) - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
put(K, V, int, long, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "put" on the key.
put(K, V, int, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
put(K, V, int, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "put" on the key.
put(K, V, int, PubSubProducerCallback, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
VeniceWriter in the leader replica should call this API to fulfill extra metadata information --- upstreamOffset.
put(K, V, int, PubSubProducerCallback, LeaderMetadataWrapper, long, PutMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
 
put(K, V, int, PubSubProducerCallback, LeaderMetadataWrapper, long, PutMetadata, ChunkedValueManifest, ChunkedValueManifest) - Method in class com.linkedin.venice.writer.VeniceWriter
Execute a standard "put" on the key.
put(K, V, int, PubSubProducerCallback, LeaderMetadataWrapper, ChunkedValueManifest, ChunkedValueManifest) - Method in class com.linkedin.venice.writer.VeniceWriter
 
put(K, V, int, PubSubProducerCallback, PutMetadata) - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
put(K, V, int, PubSubProducerCallback, PutMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
 
put(T) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
Put - Class in com.linkedin.venice.kafka.protocol
Put payloads contain a record value, and information on how to deserialize it.
Put() - Constructor for class com.linkedin.venice.kafka.protocol.Put
Default constructor.
Put(ByteBuffer, Integer, Integer, ByteBuffer) - Constructor for class com.linkedin.venice.kafka.protocol.Put
All-args constructor.
PUT - com.linkedin.venice.authorization.Method
 
PUT - com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
 
PUT - com.linkedin.venice.kafka.protocol.enums.MessageType
 
PUT_KEY_HEADER_BYTE - Static variable in class com.linkedin.venice.kafka.protocol.enums.MessageType.Constants
 
PUT_NEW_FIELD - com.linkedin.venice.schema.writecompute.WriteComputeOperation
Put a new value on an existing field.
PUT_OFFSET_RECORD - com.linkedin.venice.meta.IngestionMetadataUpdateType
 
PUT_ONLY_PART_LENGTH_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
PUT_ONLY_PART_LENGTH_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
PUT_STORE_VERSION_STATE - com.linkedin.venice.meta.IngestionMetadataUpdateType
 
putAll(Map<? extends K, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
Copies all of the mappings from the specified map to this map.
putAll(Map<K, V>) - Method in class com.linkedin.alpini.base.misc.CollectionUtil.MapBuilder
 
putByIndex(K, V, int) - Method in class com.linkedin.davinci.utils.IndexedHashMap
O(N) in the worst case.
putByIndex(K, V, int) - Method in interface com.linkedin.davinci.utils.IndexedMap
 
putByIndex(K, V, int) - Method in interface com.linkedin.venice.utils.IndexedMap
 
putConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, StoreIngestionTask, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
 
putConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, StoreIngestionTask, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
putConsumerRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, StoreIngestionTask, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
putDefaultResult(GenericRecord, Schema.Field) - Method in class com.linkedin.venice.compute.CountOperator
 
putDefaultResult(GenericRecord, Schema.Field) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
 
putDeserializedValue(K, V) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
putIfAbsent(String, Object) - Method in class com.linkedin.venice.utils.PropertyBuilder
 
putIfAbsent(K, V) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
putInStorageEngine(int, byte[], Put) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
putInStorageEngine(int, byte[], Put) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Persist Put record to storage engine.
PutMetadata - Class in com.linkedin.venice.writer
This is a simple container class to hold replication metadata related fields together to be passed on to the Put api in VeniceWriter VeniceWriter#put(Object, Object, int, Callback, LeaderMetadataWrapper, long, PutMetadata).
PutMetadata(int, ByteBuffer) - Constructor for class com.linkedin.venice.writer.PutMetadata
 
putOffsetRecord(String, int, OffsetRecord) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
putOffsetRecord will only put OffsetRecord into in-memory state, without persisting into metadata RocksDB partition.
putOnField(GenericRecord, GenericRecord, Schema.Field, Object, long, int) - Method in class com.linkedin.davinci.schema.merge.CollectionTimestampMergeRecordHelper
 
putOnField(GenericRecord, GenericRecord, Schema.Field, Object, long, int) - Method in interface com.linkedin.davinci.schema.merge.MergeRecordHelper
 
putPartitionOffset(int, OffsetRecord) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Put the offset associated with the partitionId into the metadata partition.
putReplicationMetadata(byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
putReplicationMetadata(byte[], byte[]) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
putReplicationMetadata(int, byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
putResult(GenericRecord, Schema.Field, Object) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
 
putStore(Store) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
putStore(Store) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
putStore(Store) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepository
 
putStore(Store) - Method in class com.linkedin.venice.helix.SubscriptionBasedStoreRepository
 
putStoreIntoGraveyard(String, Store) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
 
putStoreIntoGraveyard(String, Store) - Method in interface com.linkedin.venice.meta.StoreGraveyard
Put the given store into graveyard.
putStoreVersionState(StoreVersionState) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Put the store version state into the metadata partition.
putStoreVersionState(String, StoreVersionState) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
putStoreVersionState will only put StoreVersionState into in-memory state, without persisting into metadata RocksDB partition.
putStringMap(String, Map<String, String>) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
putStringSet(String, Set<String>) - Method in class com.linkedin.venice.controllerapi.QueryParams
 
putSystemStore(VeniceSystemStoreType, SystemStoreAttributes) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
putSystemStore(VeniceSystemStoreType, SystemStoreAttributes) - Method in interface com.linkedin.venice.meta.Store
 
putSystemStore(VeniceSystemStoreType, SystemStoreAttributes) - Method in class com.linkedin.venice.meta.SystemStore
 
putSystemStore(VeniceSystemStoreType, SystemStoreAttributes) - Method in class com.linkedin.venice.meta.ZKStore
 
putValue - Variable in class com.linkedin.venice.kafka.protocol.Put
The record's value to be persisted in the storage engine.
putValueChanged() - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaMessage
 
putWithReplicationMetadata(byte[], byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
This API takes in value and metadata as byte array format and put it into RocksDB.
putWithReplicationMetadata(byte[], byte[], byte[]) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
putWithReplicationMetadata(byte[], ByteBuffer, byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
This API takes in value and metadata as ByteBuffer format and put it into RocksDB.
putWithReplicationMetadata(byte[], ByteBuffer, byte[]) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
This API takes in value and metadata as ByteBuffer format and put it into RocksDB.
putWithReplicationMetadata(int, byte[], ByteBuffer, byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 

Q

QOS - Enum in com.linkedin.alpini.consts
Sets the quality of service (QOS) for the request.
QOSBasedMultiQueue<T extends QOSBasedRequestRunnable> - Class in com.linkedin.alpini.base.queuing
A fair multi-queue based upon a ring topology.
QOSBasedMultiQueue() - Constructor for class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
 
QOSBasedMultiQueue(int, int, Map<QOS, Integer>) - Constructor for class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
 
QOSBasedMultiQueue(int, Map<QOS, Integer>) - Constructor for class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
 
QOSBasedQueue<T extends QOSBasedRequestRunnable> - Class in com.linkedin.alpini.base.queuing
Implementation of SimpleQueue.
QOSBasedQueue() - Constructor for class com.linkedin.alpini.base.queuing.QOSBasedQueue
 
QOSBasedQueue(Map<QOS, Integer>) - Constructor for class com.linkedin.alpini.base.queuing.QOSBasedQueue
 
QOSBasedRequestRunnable - Class in com.linkedin.alpini.base.queuing
Wrapper class for "runnables" i.e.
QOSBasedRequestRunnable(String, QOS, Runnable) - Constructor for class com.linkedin.alpini.base.queuing.QOSBasedRequestRunnable
 
QOSFCFSQueue<T extends QOSBasedRequestRunnable> - Class in com.linkedin.alpini.base.queuing
Simple wrapper over a ConcurrentLinkedQueue to expose FCFS Queue operations.
QOSFCFSQueue() - Constructor for class com.linkedin.alpini.base.queuing.QOSFCFSQueue
 
QOSPolicy - Enum in com.linkedin.alpini.base.queuing
Enumerates all the QOS Policies supported.
QOSPolicy.Config - Class in com.linkedin.alpini.base.queuing
 
QOSPolicy.StaticConfig - Class in com.linkedin.alpini.base.queuing
 
Quantile(double, double) - Constructor for class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantile
 
Quantiles(double) - Constructor for class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantiles
 
Quantiles(double, double...) - Constructor for class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantiles
 
query(double) - Method in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation
 
query(double) - Method in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation
 
query(double) - Method in class com.linkedin.alpini.base.statistics.LongQuantileEstimation
 
query(AbstractQuantileEstimation.Quantiles) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Data
 
query(AbstractQuantileEstimation.Quantiles) - Method in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation
 
query(AbstractQuantileEstimation.Quantiles) - Method in class com.linkedin.alpini.base.statistics.LongQuantileEstimation
 
query(Instance, VenicePath, Consumer<PortableHttpResponse>, Consumer<Throwable>, BooleanSupplier) - Method in class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
 
query(Instance, VenicePath, Consumer<PortableHttpResponse>, Consumer<Throwable>, BooleanSupplier) - Method in class com.linkedin.venice.router.httpclient.HttpClient5StorageNodeClient
 
query(Instance, VenicePath, Consumer<PortableHttpResponse>, Consumer<Throwable>, BooleanSupplier) - Method in interface com.linkedin.venice.router.httpclient.StorageNodeClient
Send a request to storage node
query(String) - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
QUERY - com.linkedin.venice.Command
 
QUERY_KAFKA_TOPIC - com.linkedin.venice.Command
 
QueryAction - Enum in com.linkedin.venice.meta
 
queryAndReset(AbstractQuantileEstimation.Quantiles) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
queryAndReset(AbstractQuantileEstimation.Quantiles, Consumer<AbstractQuantileEstimation.Data>) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
queryDetailedJobStatus(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
This method will retrieve detailed job status, including uncompleted partitions and replicas from a child region.
queryJobStatus(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
queryJobStatus(String, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
This method is used to query the job status from a controller.
queryJobStatus(String, Optional<String>, int, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
queryJobStatus(String, Optional<String>, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
queryOverallJobStatus(String, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
queryOverallJobStatus(String, Optional<String>, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
This method has a longer timeout intended to be used to query the overall job status on a parent controller.
QueryParams - Class in com.linkedin.venice.controllerapi
A simple container with builder functions to sugar-coat the code a bit.
QueryParams() - Constructor for class com.linkedin.venice.controllerapi.QueryParams
 
QueryParams(Map<String, String>) - Constructor for class com.linkedin.venice.controllerapi.QueryParams
 
querySample(AbstractQuantileEstimation.Quantiles) - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
queryStoreForKey(String, String, String, boolean, Optional<String>) - Static method in class com.linkedin.venice.client.store.QueryTool
 
queryStoreList() - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
queryStoreList(boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
queryStoreList(boolean, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
QueryStringDecoder - Class in com.linkedin.alpini.base.misc
Imported this implementation from netty 3.2.4 because the implementation within 3.5.11 will corrupt uri paths, converting ';' semicolons into '&' ampersands.
QueryStringDecoder(String) - Constructor for class com.linkedin.alpini.base.misc.QueryStringDecoder
Creates a new decoder that decodes the specified URI.
QueryStringDecoder(String, String) - Constructor for class com.linkedin.alpini.base.misc.QueryStringDecoder
Deprecated.
QueryStringDecoder(String, Charset) - Constructor for class com.linkedin.alpini.base.misc.QueryStringDecoder
Creates a new decoder that decodes the specified URI encoded in the specified charset.
QueryStringDecoder(URI) - Constructor for class com.linkedin.alpini.base.misc.QueryStringDecoder
Creates a new decoder that decodes the specified URI.
QueryStringDecoder(URI, String) - Constructor for class com.linkedin.alpini.base.misc.QueryStringDecoder
Deprecated.
QueryStringDecoder(URI, Charset) - Constructor for class com.linkedin.alpini.base.misc.QueryStringDecoder
Creates a new decoder that decodes the specified URI encoded in the specified charset.
QueryTool - Class in com.linkedin.venice.client.store
A tool use thin client to query the value from a store by the specified key.
QueryTool() - Constructor for class com.linkedin.venice.client.store.QueryTool
 
QUEUED_TO_DRAINER - com.linkedin.davinci.kafka.consumer.StoreIngestionTask.DelegateConsumerRecordResult
The consumer record has been put into drainer queue; the following cases will result in putting to drainer directly: 1.
QUOTA_EXCEEDED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
QUOTA_FAILED_REGEX - Static variable in class com.linkedin.venice.utils.TestStoragePersonaUtils
 
QUOTA_NOT_VIOLATED - com.linkedin.venice.pushmonitor.HybridStoreQuotaStatus
 
QUOTA_VIOLATED - com.linkedin.venice.pushmonitor.HybridStoreQuotaStatus
 
QuotaExceededException - Exception in com.linkedin.venice.exceptions
 
QuotaExceededException(String, String, String) - Constructor for exception com.linkedin.venice.exceptions.QuotaExceededException
 
QuotaExceededException(String, String, String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.QuotaExceededException
 
quotaNotViolated(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Quota is not violated for a store.
quotaNotViolated(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
quotaNotViolated(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
quotaNotViolated(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
quotaNumber - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
quotaNumber - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
quotaViolated(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Quota is violated for a store.
quotaViolated(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
quotaViolated(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
quotaViolated(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 

R

R2TransportClient - Class in com.linkedin.venice.fastclient.transport
R2 based Transport Client Interface.
R2TransportClient(Client) - Constructor for class com.linkedin.venice.fastclient.transport.R2TransportClient
 
R2TransportClient.R2TransportClientCallback - Class in com.linkedin.venice.fastclient.transport
 
R2TransportClientCallback(CompletableFuture<TransportClientResponse>) - Constructor for class com.linkedin.venice.fastclient.transport.R2TransportClient.R2TransportClientCallback
 
RandomEventExecutorChooserFactory - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 12/12/16.
RandomEventExecutorChooserFactory() - Constructor for class com.linkedin.alpini.netty4.misc.RandomEventExecutorChooserFactory
 
RandomGenUtils - Class in com.linkedin.venice.utils
 
RandomGenUtils() - Constructor for class com.linkedin.venice.utils.RandomGenUtils
 
RandomPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
A simple PollStrategy which delivers messages from any partition, while respecting the ordering guarantee of individual partitions.
RandomPollStrategy() - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.RandomPollStrategy
 
RandomPollStrategy(boolean) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.RandomPollStrategy
 
RandomPollStrategy(int) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.RandomPollStrategy
 
randomWeakUUID() - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Static factory to retrieve a type 4 (pseudo randomly generated) UUID.
RATE_GAUGE_CACHE_DURATION_IN_SECONDS - Static variable in class com.linkedin.venice.stats.LongAdderRateGauge
 
RateLimitConnectHandler - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 3/19/18.
RateLimitConnectHandler(ScheduledExecutorService, long, long) - Constructor for class com.linkedin.alpini.netty4.handlers.RateLimitConnectHandler
 
RateLimitConnectHandler(ScheduledExecutorService, LongSupplier, LongSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.RateLimitConnectHandler
 
RateLimitConnectHandler(ScheduledExecutorService, LongSupplier, LongSupplier, LongSupplier) - Constructor for class com.linkedin.alpini.netty4.handlers.RateLimitConnectHandler
 
rateLimitCreate(AsyncPool.LifeCycle<T>, ScheduledExecutorService, long, long, long, TimeUnit) - Static method in interface com.linkedin.alpini.base.pool.AsyncPool
 
RateLimitedCreateLifeCycle<T> - Class in com.linkedin.alpini.base.pool.impl
 
RateLimitedCreateLifeCycle(AsyncPool.LifeCycle<T>, ScheduledExecutorService, long, long, long, TimeUnit) - Constructor for class com.linkedin.alpini.base.pool.impl.RateLimitedCreateLifeCycle
 
RatioStat(Rate, Rate, String) - Constructor for class com.linkedin.venice.stats.TehutiUtils.RatioStat
 
rawBytes - Variable in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
serialized bytes of the position systems
RawBytesChunkingAdapter - Class in com.linkedin.davinci.storage.chunking
A ChunkingAdapter to be used when we want to read the value from storage engine as raw bytes.
RawBytesChunkingAdapter() - Constructor for class com.linkedin.davinci.storage.chunking.RawBytesChunkingAdapter
Singleton
RawBytesStoreDeserializerCache - Class in com.linkedin.venice.serialization
 
RawBytesStoreDeserializerCache() - Constructor for class com.linkedin.venice.serialization.RawBytesStoreDeserializerCache
 
RawKeyBytesAndChunkedKeySuffix - Class in com.linkedin.venice.chunking
A POJO containing a byte array and a serialized ChunkedKeySuffix or an object of ChunkedKeySuffix
RawKeyBytesAndChunkedKeySuffix(ByteBuffer, ByteBuffer) - Constructor for class com.linkedin.venice.chunking.RawKeyBytesAndChunkedKeySuffix
 
rawPath(String, String[]) - Static method in interface com.linkedin.venice.controllerapi.routes.V1Route
Generates a path formatted with colons prefixing each path parameter for use in defining the path in SparkJava ex /user/:id
read() - Method in class com.linkedin.alpini.io.ZeroInputStream
 
read() - Method in class com.linkedin.davinci.storage.chunking.ChunkedValueInputStream
Required part of the InputStream contract, although we hope that it will generally not be called, as the alternative ChunkedValueInputStream.read(byte[], int, int) function is more efficient.
read() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
read(byte[]) - Method in class com.linkedin.alpini.io.ZeroInputStream
 
read(byte[], int, int) - Method in class com.linkedin.alpini.io.ZeroInputStream
 
read(byte[], int, int) - Method in class com.linkedin.davinci.storage.chunking.ChunkedValueInputStream
This function is an optional, but recommended, part of the InputStream contract.
read(int, byte[], AbstractAvroChunkingAdapter<V>, StoreDeserializerCache<V>, int, BinaryDecoder, ByteBuffer, V) - Method in class com.linkedin.davinci.VersionBackend
 
read(ByteBuf, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
read(ByteBuf, int) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
read(ByteBuf, int) - Method in enum com.linkedin.alpini.netty4.misc.NettyUtils.ReadMode
 
Read - com.linkedin.venice.authorization.Method
Custom Methods for Kafka
READ_CHUNK_DELIMITER - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_CHUNK_FOOTER - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_CHUNK_SIZE - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_CHUNKED_CONTENT - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_COMPUTATION_ENABLED - com.linkedin.venice.Arg
 
READ_COMPUTATION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
READ_FIXED_LENGTH_CONTENT - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_HEADER - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_INITIAL - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_OPERATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
READ_OPTIONS_DEFAULT - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
READ_OPTIONS_WITH_ASYNC_IO - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
Async IO will speed up the lookup for multi-get with posix file system.
READ_QUOTA - com.linkedin.venice.Arg
 
READ_QUOTA_IN_CU - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
READ_SYSTEM_STORE - com.linkedin.venice.authorization.Method
Custom Methods for Venice System Stores.
READ_THROTTLING_ENABLED - Static variable in class com.linkedin.venice.router.AdminOperationsHandler
 
READ_VARIABLE_LENGTH_CONTENT - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
READ_WRITE_OPERATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
READABILITY - com.linkedin.venice.Arg
 
readableBytes() - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
The number of readable bytes.
readArray() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readArrayStart() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
ReadAvroProtocolDefinition - Enum in com.linkedin.venice.schema.avro
TDOO: Consider merging with AvroProtocolDefinition
readBoolean() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readBoolean() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readBoolean(byte[], int) - Static method in class com.linkedin.venice.utils.ByteUtils
Read a boolean from the byte array starting at the given offset
readBytes(int, int) - Method in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
Utility method to read byte arrays.
readBytes(ByteBuf, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
readBytes(Object, Decoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
readBytes(ByteBuffer) - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readBytes(ByteBuffer) - Method in class org.apache.avro.io.OptimizedBinaryDecoder
 
readBytesMeta(int) - Method in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
Utility method to read bytes array metadata, which contains the byte length and the byte length to store the serialized byte-length.
readCloseRWLock - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
Since all the modification functions are synchronized, we don't need any other synchronization for the update path to guard RocksDB closing behavior.
readComputationEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether read-path computation feature is enabled for this store
readComputationEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
readComputationEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether read-path computation is enabled for this store.
ReadComputeOperator - Interface in com.linkedin.venice.compute
 
readCycleDelayMs - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
readDictionaryFromKafka(String, PubSubConsumerAdapter, PubSubTopicRepository) - Static method in class com.linkedin.venice.utils.DictionaryUtils
This function reads the kafka topic for the store version for the Start Of Push message which contains the compression dictionary.
readDictionaryFromKafka(String, VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
This function is added to allow it to be mocked for tests.
readDictionaryFromKafka(String, VeniceProperties) - Static method in class com.linkedin.venice.utils.DictionaryUtils
 
readDouble() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readEnum() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readEnum(Schema, Decoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
ReadEnvelopeChunkedDeserializer<V> - Class in com.linkedin.venice.client.store.streaming
This class provides support to deserialize customized records even the input doesn't contain the full record.
ReadEnvelopeChunkedDeserializer() - Constructor for class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
 
ReadEnvelopeChunkedDeserializer.NotEnoughBytesException - Exception in com.linkedin.venice.client.store.streaming
Exception when the deserialization hits partial record.
ReadEnvelopeChunkedDeserializer.ValueContainer<V> - Class in com.linkedin.venice.client.store.streaming
This class contains two fields: 1.
reader - Variable in class com.linkedin.venice.serializer.SerializerDeserializerFactory.SchemaPairAndClassContainer
 
READER_WRITER_COMPATIBLE_MESSAGE - Static variable in class com.linkedin.venice.schema.avro.SchemaCompatibility
Message to annotate reader/writer schema pairs that are compatible.
readExternal(ObjectInput) - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.Count
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.Delete
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.GUID
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.Put
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.Update
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.metadata.response.VersionProperties
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.participant.protocol.KillPushJob
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.pushstatus.PushStatusKey
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.pushstatus.PushStatusValue
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.storage.protocol.ChunkId
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
readExternal(ObjectInput) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
readFields(DataInput) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
 
readFixed(byte[], int, int) - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readFixed(Object, Schema, Decoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
readFloat() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readFloat() - Method in class org.apache.avro.io.OptimizedBinaryDecoder
 
readFraction() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readHttpRequestContent(FullHttpRequest) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
readIndex() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readInt() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readInt() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readInt(byte[], int) - Static method in class com.linkedin.venice.utils.ByteUtils
Read an int from the byte array starting at the given offset
readLong() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readLong(byte[], int) - Static method in class com.linkedin.venice.utils.ByteUtils
Read a long from the byte array starting at the given offset
readMap(Object, Schema, ResolvingDecoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
readMap(Map<String, Object>) - Method in class com.linkedin.venice.schema.vson.VsonSchemaAdapter
Deprecated.
 
readMapStart() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
ReadMetadataRetriever - Interface in com.linkedin.davinci.storage
 
readMode() - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
readNull() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readNull() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readNumber() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readObject() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readOnly - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
Whether the database is read only or not.
readOnlyForBatchOnlyStoreEnabled - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
ReadOnlyLiveClusterConfigRepository - Interface in com.linkedin.venice.meta
 
ReadOnlyPartitionStatus - Class in com.linkedin.venice.pushmonitor
 
ReadOnlyPartitionStatus(int, Collection<ReplicaStatus>) - Constructor for class com.linkedin.venice.pushmonitor.ReadOnlyPartitionStatus
 
ReadOnlySchemaRepository - Interface in com.linkedin.venice.meta
 
ReadOnlyStore - Class in com.linkedin.venice.meta
A read-only wrapper of Store, and all the modification to delegated instance will throw UnsupportedOperationException.
ReadOnlyStore(Store) - Constructor for class com.linkedin.venice.meta.ReadOnlyStore
 
ReadOnlyStore.ReadOnlyVersion - Class in com.linkedin.venice.meta
A read-only wrapper of Version
ReadOnlyStoreConfigRepository - Interface in com.linkedin.venice.meta
Interface defined the way to retrieve the store config from a repository.
ReadOnlyStoreRepository - Interface in com.linkedin.venice.meta
Interface defined readonly operations to access stores.
ReadOnlyVersion(Version) - Constructor for class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
ReadOnlyViewConfig - Class in com.linkedin.venice.meta
 
ReadOnlyViewConfig(ViewConfig) - Constructor for class com.linkedin.venice.meta.ReadOnlyViewConfig
 
ReadPersona - Class in com.linkedin.venice.persona
A type of Persona that enforces a read (bandwidth) limit across multiple stores.
ReadPersona(String, long, Set<String>, Set<String>) - Constructor for class com.linkedin.venice.persona.ReadPersona
 
ReadQuotaEnforcementHandler - Class in com.linkedin.venice.listener
 
ReadQuotaEnforcementHandler(long, ReadOnlyStoreRepository, CompletableFuture<HelixCustomizedViewOfflinePushRepository>, String, AggServerQuotaUsageStats, MetricsRepository) - Constructor for class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
ReadQuotaEnforcementHandler(long, ReadOnlyStoreRepository, CompletableFuture<HelixCustomizedViewOfflinePushRepository>, String, AggServerQuotaUsageStats, MetricsRepository, Clock) - Constructor for class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
readQuotaInCU - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
readQuotaInCU - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
readQuotaInCU - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Quota for read request hit this store.
readRecord(Object, Schema, ResolvingDecoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
ReadRequestThrottler - Class in com.linkedin.venice.router.throttle
This class define the throttler on reads request.
ReadRequestThrottler(ZkRoutersClusterManager, ReadOnlyStoreRepository, long, AggRouterHttpRequestStats, double, long) - Constructor for class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
ReadRequestThrottler(ZkRoutersClusterManager, ReadOnlyStoreRepository, AggRouterHttpRequestStats, VeniceRouterConfig) - Constructor for class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
ReadResponse - Class in com.linkedin.davinci.listener.response
This class is used to store common fields shared by various read responses.
ReadResponse() - Constructor for class com.linkedin.davinci.listener.response.ReadResponse
 
readRetainedSlice(ByteBuf, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
readSchema() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputScan
 
readShort(byte[], int) - Static method in class com.linkedin.venice.utils.ByteUtils
Read a short from the byte array starting at the given offset
readStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
readStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
How to read data from multiple replications, and default is 'ANY_OF_ONLINE'
ReadStrategy - Enum in com.linkedin.venice.meta
Enums of the strategies used to read data from multiple replications in Venice.
readString() - Method in class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
readString() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
readString(Object, Schema, Decoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
readString(Utf8) - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
ReadWriteLiveClusterConfigRepository - Interface in com.linkedin.venice.meta
 
ReadWriteSchemaRepository - Interface in com.linkedin.venice.meta
 
ReadWriteStoreRepository - Interface in com.linkedin.venice.meta
Interface defined read and write operations to access stores.
READY - com.linkedin.venice.controllerapi.NodeReplicasReadinessState
Node is live and all current version replicas are ready.
READY_TO_SERVE_WITH_RT_LAG_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
ReadyForDataRecoveryResponse - Class in com.linkedin.venice.controllerapi
 
ReadyForDataRecoveryResponse() - Constructor for class com.linkedin.venice.controllerapi.ReadyForDataRecoveryResponse
 
REAL_TIME_TOPIC_SUFFIX - Static variable in interface com.linkedin.venice.meta.Version
 
REALTIME_TOPIC - com.linkedin.venice.pubsub.api.PubSubTopicType
 
realTimeTopic - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
RealTimeTopicSwitcher - Class in com.linkedin.venice.ingestion.control
Class which implements the process of switching from a batch topic (e.g.
RealTimeTopicSwitcher(TopicManager, VeniceWriterFactory, VeniceProperties, PubSubTopicRepository) - Constructor for class com.linkedin.venice.ingestion.control.RealTimeTopicSwitcher
 
receivedRecordsCount() - Method in class com.linkedin.davinci.kafka.consumer.StorePartitionDataReceiver
 
record() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
record() - Method in class com.linkedin.venice.stats.LongAdderRateGauge
 
record(double, long) - Method in class com.linkedin.davinci.stats.WritePathLatencySensor
Record the latency value.
record(long) - Method in class com.linkedin.venice.stats.LongAdderRateGauge
 
record(String, int, PushJobDetails) - Method in class com.linkedin.venice.hadoop.NoOpSentPushJobDetailsTracker
 
record(String, int, PushJobDetails) - Method in interface com.linkedin.venice.hadoop.SentPushJobDetailsTracker
 
RECORD_CHANGE_EVENT - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Value schema for change capture event.
RECORD_TOO_LARGE_FAILED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
RECORD_TOO_LARGE_FAILURE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
RECORD_TRANSFORMER_VALUE_SCHEMA - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
recordAdminConsumptionCycleDurationMs(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAdminMessageAddVersionProcessLatency(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAdminMessageDelegateLatency(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAdminMessageMMLatency(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAdminMessageProcessLatency(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAdminMessageStartProcessingLatency(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAdminMessageTotalLatency(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAdminRequest() - Method in class com.linkedin.venice.router.stats.AdminOperationsStats
 
recordAdminTopicDIVErrorReportCount() - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordAllowed(long) - Method in class com.linkedin.venice.stats.ServerQuotaUsageStats
 
recordAllowed(String, long) - Method in class com.linkedin.venice.stats.AggServerQuotaUsageStats
 
recordAllowedRetryRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordAllowedRetryRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordAllowedUnintentionally(long) - Method in class com.linkedin.venice.stats.ServerQuotaUsageStats
 
recordAllowedUnintentionally(String, long) - Method in class com.linkedin.venice.stats.AggServerQuotaUsageStats
 
recordAppTimedOutRequest() - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordAppTimedOutRequestResultRatio(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordAvgPartitionsPerConsumer(int) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordBackupVersionDatabaseOptimization() - Method in class com.linkedin.venice.stats.BackupVersionOptimizationServiceStats
 
recordBackupVersionDatabaseOptimizationError() - Method in class com.linkedin.venice.stats.BackupVersionOptimizationServiceStats
 
recordBackupVersionMismatch() - Method in class com.linkedin.venice.controller.stats.StoreBackupVersionCleanupServiceStats
 
recordBadRequest() - Method in class com.linkedin.davinci.StoreBackendStats
 
recordBadRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordBadRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordBadRequestKeyCount(int) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordBadRequestKeyCount(String, int) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordBasicMetrics(ServerHttpRequestStats) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
recordBenignLeaderOffsetRewind() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordBenignLeaderOffsetRewind(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordBenignLeaderProducerFailure() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordBenignLeaderProducerFailure(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordBlockedInstanceCount(int) - Method in class com.linkedin.venice.fastclient.stats.ClusterStats
 
recordBytesConsumed(long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordBytesConsumed(String, int, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordByteSizePerPoll(double) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
RecordChangeEvent - Class in com.linkedin.venice.client.change.capture.protocol
Schema which describes a record change event in a Venice store.
RecordChangeEvent() - Constructor for class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Default constructor.
RecordChangeEvent(ValueBytes, ValueBytes, ByteBuffer, List<Long>) - Constructor for class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
All-args constructor.
RecordChangeEventReadOnlySchemaRepository - Class in com.linkedin.davinci.consumer
TODO: This class is a bit of a hack.
recordCheckLongRunningTasksLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordChecksumVerificationFailure() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
recordChecksumVerificationFailure() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordClearDisabledPartition(int) - Method in class com.linkedin.venice.controller.stats.DisabledPartitionStats
 
recordClientFutureTimeout(long) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordCompressedResponseSize(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordCompressedResponseSize(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordConnectionLeaseRequestLatency(long) - Method in class com.linkedin.venice.stats.HttpConnectionPoolStats
 
recordConsumedRecordEndToEndProcessingLatency(double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordConsumedRecordEndToEndProcessingLatency(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordConsumerIdleTime(double) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordConsumerRecordsProducingToWriterBufferLatency(double) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordConsumerRecordsQueuePutLatency(double, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordCorruptedMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordCorruptedMsg(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordCosineSimilarityCount(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordCountOperator(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordCurrentVersion(VersionBackend) - Method in class com.linkedin.davinci.StoreBackendStats
 
recordDatabaseLookupLatency(double, boolean) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordDecompressionTime(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordDecompressionTime(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordDelayConstraintAbortedRetryRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordDelayConstraintAbortedRetryRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordDelegateSubscribeLatency(double) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordDeletableTopicsCount(int) - Method in class com.linkedin.venice.controller.stats.TopicCleanupServiceStats
 
recordDeleteRequest() - Method in class com.linkedin.venice.producer.VeniceProducerMetrics
 
RecordDeserializer<T> - Interface in com.linkedin.venice.serializer
 
recordDetectedDeletedTopicNum(int) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordDetectedNoRunningIngestionTopicPartitionNum(int) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordDisabledPartition() - Method in class com.linkedin.venice.controller.stats.DisabledPartitionStats
 
recordDisallowedRetryRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordDisallowedRetryRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordDotProductCount(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordDuplicateMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordDuplicateMsg(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordEarlyTerminatedEarlyRequest() - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordErrorAdminRequest() - Method in class com.linkedin.venice.router.stats.AdminOperationsStats
 
recordErrorHealthCheck() - Method in class com.linkedin.venice.router.stats.HealthCheckStats
 
recordErrorPartitionProcessingTime(double) - Method in class com.linkedin.venice.controller.stats.ErrorPartitionStats
 
recordErrorPartitionRecoveredFromReset() - Method in class com.linkedin.venice.controller.stats.ErrorPartitionStats
 
recordErrorPartitionResetAttempt(double) - Method in class com.linkedin.venice.controller.stats.ErrorPartitionStats
 
recordErrorPartitionResetAttemptErrored() - Method in class com.linkedin.venice.controller.stats.ErrorPartitionStats
 
recordErrorPartitionUnrecoverableFromReset() - Method in class com.linkedin.venice.controller.stats.ErrorPartitionStats
 
recordErrorRequest() - Method in class com.linkedin.venice.stats.AggServerHttpRequestStats
 
recordErrorRequest() - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordErrorRequestLatency(double) - Method in class com.linkedin.venice.stats.AggServerHttpRequestStats
 
recordErrorRequestLatency(double) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordErrorRetryAttemptTriggeredByPendingRequestCheck() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordErrorRetryAttemptTriggeredByPendingRequestCheck(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordErrorRetryCount() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordErrorRetryCount(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordErrorRetryRequest() - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordException(String, int, DataValidationException) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordFailedAdminConsumption() - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
Record the number of failed admin messages in the past one minute; if controller keeps retrying the admin messages, this metric will keep growing; this metric will be reset to 0 once the blocked admin message is processed.
recordFailedInitialization() - Method in class com.linkedin.davinci.stats.ParticipantStoreConsumptionStats
 
recordFailedLeakedPushStatusCleanUpCount(int) - Method in class com.linkedin.venice.pushmonitor.AggPushStatusCleanUpStats
 
recordFailedLeakedPushStatusCleanUpCount(int) - Method in class com.linkedin.venice.pushmonitor.PushStatusCleanUpStats
 
recordFailedPush(long) - Method in class com.linkedin.venice.pushmonitor.PushHealthStats
 
recordFailedPush(String, long) - Method in class com.linkedin.venice.pushmonitor.AggPushHealthStats
 
recordFailedRequest() - Method in class com.linkedin.venice.producer.VeniceProducerMetrics
 
recordFailedRequestLatency(double) - Method in class com.linkedin.venice.controller.stats.SparkServerStats
 
recordFailedRetriableAdminConsumption() - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordFanoutRequestCount(int) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordFanoutRequestCount(String, int) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordFastClientErrorThinClientSucceedRequest() - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordFastClientSlowerRequest() - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordFindUnhealthyHostRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordFindUnhealthyHostRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordFinishedRequest(String) - Method in class com.linkedin.venice.router.stats.RouteHttpRequestStats
 
recordFollowerBytesConsumed(long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordFollowerConsumed(String, int, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordFollowerHeartbeat(String, int, int, String, Long) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
Record a follower heartbeat timestamp for a given partition of a store version from a specific region.
recordFollowerLag(String, int, String, long) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatVersionedStats
 
recordFollowerLag(String, long) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
 
recordFollowerLatencies(String, int, long, double, double) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordFollowerRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordForkedProcessRestart() - Method in class com.linkedin.davinci.stats.IsolatedIngestionProcessHeartbeatStats
 
recordFutureVersion(VersionBackend) - Method in class com.linkedin.davinci.StoreBackendStats
 
recordGroupNum(int) - Method in class com.linkedin.venice.router.stats.HelixGroupStats
 
recordGroupRequest(int) - Method in class com.linkedin.venice.router.stats.HelixGroupStats
 
recordHadamardProduct(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordHealthCheck() - Method in class com.linkedin.venice.router.stats.HealthCheckStats
 
recordHealthyLatency(double) - Method in class com.linkedin.venice.client.stats.BasicClientStats
 
recordHealthyRequest() - Method in class com.linkedin.venice.client.stats.BasicClientStats
 
recordHealthyRequest(Double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordHealthyRequest(String) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordHealthyRequest(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordHeartbeat() - Method in class com.linkedin.davinci.stats.ParticipantStoreConsumptionStats
 
recordHeartbeatAge(long) - Method in class com.linkedin.davinci.stats.IsolatedIngestionProcessHeartbeatStats
 
recordHeartbeatReceived(PartitionConsumptionState, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, String) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
recordHeartbeatReceived(PartitionConsumptionState, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, String) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
recordHttpRequest(int) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordIdleTime(long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordInconsistentStoreMetadata() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionActiveActiveDeleteLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionActiveActivePutLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionActiveActiveUpdateLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionFailure() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionFailure(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
recordIngestionFailure(String) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
 
recordIngestionReplicationMetadataCacheHitCount(long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionReplicationMetadataLookUpLatency(double, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionTaskRepair() - Method in class com.linkedin.davinci.stats.StuckConsumerRepairStats
 
recordIngestionValueBytesCacheHitCount(long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordIngestionValueBytesLookUpLatency(double, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordInternalProcessingError() - Method in class com.linkedin.davinci.stats.StoreBufferServiceStats
 
recordInternalProcessingLatency(long) - Method in class com.linkedin.davinci.stats.StoreBufferServiceStats
 
recordInternalServerErrorRequest(String) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordKeyNum(int) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordKeyNum(String, int) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordKeySize(long, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordKeySize(String, long) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordKeySizeInByte(long) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordKeySizeInByte(long) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordKilledPushJobs() - Method in class com.linkedin.davinci.stats.ParticipantStoreConsumptionStats
 
recordKillPushJobFailedConsumption() - Method in class com.linkedin.davinci.stats.ParticipantStoreConsumptionStats
 
recordKillPushJobLatency(double) - Method in class com.linkedin.davinci.stats.ParticipantStoreConsumptionStats
 
recordLag(Long) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
 
recordLags(Map<String, Map<Integer, Map<Integer, Map<String, Long>>>>, HeartbeatMonitoringService.ReportLagFunction) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
recordLatency(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordLatency(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordLatestOffsetIsAbsent() - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordLatestOffsetIsPresent() - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordLeaderBytesConsumed(long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordLeaderBytesProduced(long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordLeaderConsumed(String, int, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordLeaderDIVCompletionLatencyMs(double, long) - Method in class com.linkedin.davinci.stats.DIVStats
 
recordLeaderDIVCompletionTime(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordLeaderHeartbeat(String, int, int, String, Long) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
Record a leader heartbeat timestamp for a given partition of a store version from a specific region.
recordLeaderLag(String, int, String, long) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatVersionedStats
 
recordLeaderLag(String, long) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
 
recordLeaderLatencies(String, int, long, double, double) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordLeaderProduced(String, int, long, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordLeaderProducerCompletionLatencyMs(double, long) - Method in class com.linkedin.davinci.stats.DIVStats
 
recordLeaderProducerCompletionTime(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordLeaderProducerFailure() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordLeaderProducerFailure(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordLeaderProducerSynchronizeLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordLeaderRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordLeaderRecordsProduced(long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordLeakedPendingRequestCount() - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordLeakedPendingRequestCount(String) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordLeakedPushStatusCleanUpServiceState(PushStatusCleanUpServiceState) - Method in class com.linkedin.venice.pushmonitor.AggPushStatusCleanUpStats
 
recordLeakedPushStatusCleanUpServiceState(PushStatusCleanUpServiceState) - Method in class com.linkedin.venice.pushmonitor.PushStatusCleanUpStats
3 possible metric values: 1: the leaked push status clean-up service is up and running 0: the leaked push status clean-up service is stopped gracefully or stopped by InterruptException -1: the leaked push status clean-up service crashes while the Venice service is still running
recordLeakedPushStatusCount(int) - Method in class com.linkedin.venice.pushmonitor.AggPushStatusCleanUpStats
 
recordLeakedPushStatusCount(int) - Method in class com.linkedin.venice.pushmonitor.PushStatusCleanUpStats
 
recordLeakedRequest(String) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordLeakedVersion() - Method in class com.linkedin.venice.stats.LeakedResourceCleanerStats
 
recordLevelMetricEnabled - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
recordLocalBrokerFollowerConsumerLatencyMs(double, long) - Method in class com.linkedin.davinci.stats.DIVStats
 
recordLongTailRetryRequest() - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordLookupLatency(long) - Method in class com.linkedin.venice.stats.DnsLookupStats
 
recordMaxIdleTime(String, int, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordMaxPartitionsPerConsumer(int) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordMessageErrored(Exception) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
recordMetadataQueueUpdateError(double) - Method in class com.linkedin.davinci.stats.MetadataUpdateStats
 
recordMetadataUpdateQueueLength(int) - Method in class com.linkedin.davinci.stats.MetadataUpdateStats
 
recordMetaStoreShadowRead() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordMetaStoreShadowRead(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordMinPartitionsPerConsumer(int) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordMisroutedStoreVersionRequest() - Method in class com.linkedin.venice.stats.AggServerHttpRequestStats
 
recordMisroutedStoreVersionRequest() - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordMissedStorageNodesReplyCount(double) - Method in class com.linkedin.venice.stats.HelixMessageChannelStats
 
recordMissingMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordMissingMsg(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordMultiChunkLargeValueCount(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordMultiGetFallback(int) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordMultiGetFallback(int) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordMultiGetFallback(String, int) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordNearlineLocalBrokerToReadyToServeLatency(double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordNearlineLocalBrokerToReadyToServeLatency(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordNearlineProducerToLocalBrokerLatency(double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordNearlineProducerToLocalBrokerLatency(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordNoAvailableReplicaAbortedRetryRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordNoAvailableReplicaAbortedRetryRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordNoAvailableReplicaRequest() - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordNonSslRequest() - Method in class com.linkedin.venice.router.stats.SecurityStats
Record all HTTP requests received in routers.
recordNonZeroPollResultNum(int) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordNotStale() - Method in class com.linkedin.venice.router.stats.StaleVersionStats
 
recordOffsetLagIsAbsent() - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordOffsetLagIsPresent() - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordOffsetRegressionDCRError() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordOffsetRegressionDCRError() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordOffsetRegressionDCRError(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordOnReplyFromStorageNodesCount() - Method in class com.linkedin.venice.stats.HelixMessageChannelStats
 
recordOriginalRequestStartTimestamp() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
recordOtherErrorRequest(String) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordPendingAdminMessagesCount(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
recordPendingRequest(String) - Method in class com.linkedin.venice.router.stats.RouteHttpRequestStats
 
recordPendingRequestCount(long) - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordPendingRequestCount(long) - Method in class com.linkedin.venice.stats.HttpConnectionPoolStats
 
recordPendingRequestCount(String, int) - Method in class com.linkedin.venice.fastclient.stats.ClusterStats
 
recordPendingRequestCount(String, long) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordPendingRequestUnhealthyDuration(String, double) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordPollError() - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordPollRequestLatency(double) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordPollResultNum(int) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordPotentiallyLossyLeaderOffsetRewind() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordPotentiallyLossyLeaderOffsetRewind(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordProcessConsumerActionLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordProcessedRecordStats(PartitionConsumptionState, int) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
recordProcessedRecordStats(PartitionConsumptionState, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
recordProducerCallBackLatency(double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordProducerCallBackLatency(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordProducerLocalBrokerLatencyMs(double, long) - Method in class com.linkedin.davinci.stats.DIVStats
 
recordProducerSourceBrokerLatencyMs(double, long) - Method in class com.linkedin.davinci.stats.DIVStats
 
recordPushPreparationDuration(long) - Method in class com.linkedin.venice.pushmonitor.PushHealthStats
 
recordPushPreparationDuration(String, long) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
recordPushPreparationDuration(String, long) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
stats related operation.
recordPushPreparationDuration(String, long) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
recordPushPrepartionDuration(String, long) - Method in class com.linkedin.venice.pushmonitor.AggPushHealthStats
 
recordPutRequest() - Method in class com.linkedin.venice.producer.VeniceProducerMetrics
 
recordQuota(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordQuota(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordQuotaExceededRequest(String) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordReadComputeDeserializationLatency(double, boolean) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordReadComputeEfficiency(double) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordReadComputeLatency(double, boolean) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordReadComputeSerializationLatency(double, boolean) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordReadQuotaUsage(int) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
Record read quota usage based on healthy KPS.
recordReadQuotaUsage(String, int) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
Calculate read quota usage based on how many key/value pairs are successfully returned from server.
recordReadUsage(String) - Method in class com.linkedin.venice.cleaner.BackupVersionOptimizationService
 
recordReadUsage(String) - Method in interface com.linkedin.venice.cleaner.ResourceReadUsageTracker
 
recordRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordRecordsConsumed(int) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
 
recordRecordsConsumed(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordRegionHybridAvgConsumedOffset(int, double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordRegionHybridBytesConsumed(int, double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordRegionHybridConsumption(String, int, int, long, long, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordRegionHybridRecordsConsumed(int, double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordRejected(long) - Method in class com.linkedin.venice.stats.ServerQuotaUsageStats
 
recordRejected(String, long) - Method in class com.linkedin.venice.stats.AggServerQuotaUsageStats
 
recordRejectedRetry() - Method in class com.linkedin.venice.fastclient.stats.RetryManagerStats
 
recordRepairFailure() - Method in class com.linkedin.davinci.stats.StuckConsumerRepairStats
 
recordRequest() - Method in class com.linkedin.venice.controller.stats.SparkServerStats
 
recordRequest() - Method in class com.linkedin.venice.fastclient.meta.RetryManager
 
recordRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
We record this at the beginning of request handling, so we don't know the latency yet...
recordRequest(String) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordRequestBasedMetadataFailureCount() - Method in class com.linkedin.davinci.stats.ServerMetadataServiceStats
 
recordRequestBasedMetadataInvokeCount() - Method in class com.linkedin.davinci.stats.ServerMetadataServiceStats
 
recordRequestFirstPartLatency(double) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordRequestKeyCount(int) - Method in class com.linkedin.venice.client.stats.BasicClientStats
 
recordRequestKeyCount(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordRequestParsingLatency(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordRequestParsingLatency(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordRequestPartCount(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordRequestPartsInvokeDelayLatency(double) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordRequestRetryCount() - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordRequestRoutingLatency(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordRequestRoutingLatency(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordRequestSecondPartLatency(double) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordRequestSerializationTime(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordRequestSize(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordRequestSize(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordRequestSizeInBytes(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordRequestSubmissionToResponseHandlingTime(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordRequestThrottledByRouterCapacity() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordRequestThrottledByRouterCapacity(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordRequestUsage(int) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordRequestUsage(String, int) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordResponse() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordResponse(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordResponseDecompressionTime(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordResponseDeserializationTime(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordResponseSize(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordResponseSize(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordResponseWaitingTime(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordResponseWaitingTime(String, double) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordResponseWaitingTime(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordResponseWaitingTime(String, double) - Method in class com.linkedin.venice.router.stats.RouteHttpStats
 
recordRetryCount(RequestType) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
recordRetryDelay(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordRetryDelay(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordRetryRequestKeyCount(int) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordRetryRequestSuccessKeyCount(int) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordRetryRequestWin() - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordRetryRouteLimitAbortedRetryRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordRetryRouteLimitAbortedRetryRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordRocksDBOpenFailure(String) - Method in class com.linkedin.davinci.stats.AggVersionedStorageEngineStats
 
recordRouterThrottledRequest() - Method in class com.linkedin.venice.router.stats.RouterThrottleStats
 
records - Variable in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
 
RECORDS_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
RecordSerializer<T> - Interface in com.linkedin.venice.serializer
 
recordServiceUnavailableRequest(String) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordSlowRouteAbortedRetryRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordSlowRouteAbortedRetryRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordSourceBrokerLeaderConsumerLatencyMs(double, long) - Method in class com.linkedin.davinci.stats.DIVStats
 
recordSslError() - Method in class com.linkedin.venice.router.stats.SecurityStats
 
recordSslSuccess() - Method in class com.linkedin.venice.router.stats.SecurityStats
 
recordStale(int, int) - Method in class com.linkedin.venice.router.stats.StaleVersionStats
 
recordStalenessReason(StaleVersionReason) - Method in class com.linkedin.venice.router.stats.StaleVersionStats
 
recordStorageEngineDeleteLatency(double, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordStorageEnginePutLatency(double, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordStorageExecutionHandlerSubmissionWaitTime(double) - Method in class com.linkedin.venice.stats.AggServerHttpRequestStats
 
recordStorageExecutionHandlerSubmissionWaitTime(double) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordStorageExecutionQueueLen(int) - Method in class com.linkedin.venice.stats.AggServerHttpRequestStats
 
recordStorageExecutionQueueLen(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordStorageQuotaUsed(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordStoresWithPendingAdminMessagesCount(double) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
RecordStreamDecoder - Interface in com.linkedin.venice.client.store.streaming
 
recordStreamingResponseTimeToReceive50PctRecord(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordStreamingResponseTimeToReceive90PctRecord(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordStreamingResponseTimeToReceive95PctRecord(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordStreamingResponseTimeToReceive99PctRecord(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordStreamingResponseTimeToReceiveFirstRecord(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordStuckConsumerFound() - Method in class com.linkedin.davinci.stats.StuckConsumerRepairStats
 
recordSubPartitionStatus(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
recordSubPartitionStatus(String) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
recordSubscribeDuration(Duration) - Method in class com.linkedin.davinci.StoreBackendStats
 
recordSubscribePrepLatency(double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordSubscribePrepLatency(String, int, double) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordSubtype(String) - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
recordSuccessDuplicateRequestKeyCount(int) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordSuccessfulLeakedPushStatusCleanUpCount(int) - Method in class com.linkedin.venice.pushmonitor.AggPushStatusCleanUpStats
 
recordSuccessfulLeakedPushStatusCleanUpCount(int) - Method in class com.linkedin.venice.pushmonitor.PushStatusCleanUpStats
 
recordSuccessfullyStartedUserBatchPushParentAdminCount() - Method in class com.linkedin.venice.controller.stats.VeniceAdminStats
 
recordSuccessfullyStartedUserIncrementalPushParentAdminCount() - Method in class com.linkedin.venice.controller.stats.VeniceAdminStats
 
recordSuccessfulPush(long) - Method in class com.linkedin.venice.pushmonitor.PushHealthStats
 
recordSuccessfulPush(String, long) - Method in class com.linkedin.venice.pushmonitor.AggPushHealthStats
 
recordSuccessfulPushGauge(long) - Method in class com.linkedin.venice.pushmonitor.PushHealthStats
 
recordSuccessfulPushGauge(String, long) - Method in class com.linkedin.venice.pushmonitor.AggPushHealthStats
 
recordSuccessfulRequestLatency(double) - Method in class com.linkedin.venice.controller.stats.SparkServerStats
 
recordSuccessfulRequestWithLatency(long) - Method in class com.linkedin.venice.producer.VeniceProducerMetrics
 
recordSuccessMsg() - Method in class com.linkedin.davinci.stats.DIVStats
 
recordSuccessMsg(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
recordSuccessRequest() - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordSuccessRequestKeyCount(int) - Method in class com.linkedin.venice.client.stats.BasicClientStats
 
recordSuccessRequestKeyCount(int) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordSuccessRequestLatency(double) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordTardyRequest(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordTardyRequest(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordThinClientFastClientLatencyDelta(double) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
recordThrottledRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
Once we stop reporting throttled requests in RouterExceptionAndTrackingUtils, and we only report them in VeniceResponseAggregator then we will always have a latency and we'll be able to remove this overload.
recordThrottledRequest(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordThrottledRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
Once we stop reporting throttled requests in RouterExceptionAndTrackingUtils, and we only report them in VeniceResponseAggregator then we will always have a latency and we'll be able to remove this overload.
recordThrottledRequest(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordTimestampRegressionDCRError() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTimestampRegressionDCRError() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordTimestampRegressionDCRError(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordTombstoneCreatedDCR() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTombStoneCreationDCR() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordTombStoneCreationDCR(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
RecordTooLargeException - Exception in com.linkedin.venice.exceptions
 
RecordTooLargeException(String) - Constructor for exception com.linkedin.venice.exceptions.RecordTooLargeException
 
RecordTooLargeException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.RecordTooLargeException
 
recordTooLargeFailureCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
recordTopicDeleted() - Method in class com.linkedin.venice.controller.stats.TopicCleanupServiceStats
 
recordTopicDeletionError() - Method in class com.linkedin.venice.controller.stats.TopicCleanupServiceStats
 
recordToStorageNodesInvokeCount() - Method in class com.linkedin.venice.stats.HelixMessageChannelStats
 
recordToStorageNodesMessageCount(double) - Method in class com.linkedin.venice.stats.HelixMessageChannelStats
 
recordTotalAvgPartitionsPerConsumer(int) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalBytesConsumed(long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
Record a host-level byte consumption rate across all store versions
recordTotalBytesReadFromKafkaAsUncompressedSize(long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalConsumerIdleTime(double) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalConsumerRecordsProducingToWriterBufferLatency(double) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalDCR() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordTotalDCR(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordTotalDelegateSubscribeLatency(double) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalDetectedDeletedTopicNum(int) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalDetectedNoRunningIngestionTopicPartitionNum(int) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalFollowerBytesConsumed(long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalFollowerRecordsConsumed() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalLatestOffsetIsAbsent() - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalLatestOffsetIsPresent() - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalLeaderBytesConsumed(long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalLeaderBytesProduced(long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalLeaderRecordsConsumed() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalLeaderRecordsProduced(int) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalMaxPartitionsPerConsumer(int) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalMinPartitionsPerConsumer(int) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalNonZeroPollResultNum(int) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalOffsetLagIsAbsent() - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalOffsetLagIsPresent() - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalPollError() - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalPollRequestLatency(double) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTotalQuota(double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordTotalRecordsConsumed() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
Record a host-level record consumption rate across all store versions
recordTotalRegionHybridBytesConsumed(int, long, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordTotalUpdateCurrentAssignmentLatency(double) - Method in class com.linkedin.davinci.stats.AggKafkaConsumerServiceStats
 
recordTransformerError(double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordTransformerError(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordTransformerLatency(double, long) - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordTransformerLatency(String, int, double, long) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordUnavailableReplicaStreamingRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordUnavailableReplicaStreamingRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordUnavailableReplicaStreamingRequest(String, RequestType) - Static method in class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
 
recordUnavailableRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordUnavailableRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordUnderReplicatePartition(int) - Method in class com.linkedin.venice.controller.stats.PartitionHealthStats
 
recordUnexpectedMessage() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordUnexpectedTopicAbsenceCount() - Method in class com.linkedin.venice.controller.stats.VeniceAdminStats
 
recordUnhealthyHostCountCausedByPendingQueue(int) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordUnhealthyHostCountCausedByPendingQueue(int) - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordUnhealthyHostCountCausedByRouterHeartBeat(int) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordUnhealthyHostCountCausedByRouterHeartBeat(int) - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordUnhealthyHostDelayJoin() - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordUnhealthyHostDelayJoin(String) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordUnhealthyHostHeartBeatFailure() - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordUnhealthyHostHeartBeatFailure(String) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordUnhealthyHostOfflineInstance() - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordUnhealthyHostOfflineInstance(String) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordUnhealthyHostTooManyPendingRequest() - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordUnhealthyHostTooManyPendingRequest(String) - Method in class com.linkedin.venice.router.stats.AggHostHealthStats
 
recordUnhealthyInstanceCount(int) - Method in class com.linkedin.venice.fastclient.stats.ClusterStats
 
recordUnhealthyLatency(double) - Method in class com.linkedin.venice.client.stats.ClientStats
 
recordUnhealthyPendingQueueDuration(double) - Method in class com.linkedin.venice.router.stats.HostHealthStats
 
recordUnhealthyQueueDuration(String, double) - Method in class com.linkedin.venice.router.stats.RouteHttpRequestStats
 
recordUnhealthyRequest() - Method in class com.linkedin.venice.client.stats.BasicClientStats
 
recordUnhealthyRequest() - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordUnhealthyRequest(double) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
recordUnhealthyRequest(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordUnhealthyRequest(String, double) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
 
recordUpdateCurrentAssignmentLatency(double) - Method in class com.linkedin.davinci.stats.KafkaConsumerServiceStats
 
recordUpdateIgnoredDCR() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordUpdateIgnoredDCR() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordUpdateIgnoredDCR(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordUpdateRequest() - Method in class com.linkedin.venice.producer.VeniceProducerMetrics
 
recordValueSize(long, long) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordValueSizeInByte(long) - Method in class com.linkedin.venice.stats.ServerHttpRequestStats
 
recordVersionedAndTotalStat(String, int, Consumer<STATS>) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
recordVersionTopicEndOffsetRewind() - Method in class com.linkedin.davinci.stats.IngestionStats
 
recordVersionTopicEndOffsetRewind(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
recordVersionUpdateFailure() - Method in class com.linkedin.venice.fastclient.stats.ClusterStats
 
recordViewProducerLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordWriteComputeCacheHitCount() - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordWriteComputeLookUpLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordWriteComputeUpdateLatency(double) - Method in class com.linkedin.davinci.stats.HostLevelIngestionStats
 
recordWriterStats(long, long, long, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
recordWriterStats(long, long, long, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
recover(ZkClient, PubSubConsumerAdapter, Optional<SSLFactory>, String, String, boolean, boolean, List<String>, String) - Static method in class com.linkedin.venice.RecoverStoreMetadata
 
RECOVER_CLUSTER - com.linkedin.venice.Arg
 
RECOVER_STORE_METADATA - com.linkedin.venice.Command
 
RecoverStoreMetadata - Class in com.linkedin.venice
 
RecoverStoreMetadata() - Constructor for class com.linkedin.venice.RecoverStoreMetadata
 
RECOVERY_COMMAND - com.linkedin.venice.Arg
 
RECURSION_IN_PROGRESS - com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaCompatibilityType
Used internally to tag a reader/writer schema pair and prevent recursion.
recursiveClassEquals(Throwable, Class...) - Static method in class com.linkedin.venice.utils.ExceptionUtils
Inspects a given Throwable as well as its nested causes, in order to look for a specific set of exception classes.
recursiveMessageContains(Throwable, String) - Static method in class com.linkedin.venice.utils.ExceptionUtils
Inspects a given Throwable as well as its nested causes, in order to look for a specific message.
redirect(PrintWriter, PrintWriter) - Method in class com.linkedin.alpini.cli.CLIArgumentParser
 
redirectErrorStream() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
redirectErrorStream(boolean) - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
reduce(BytesWritable, Iterator<BytesWritable>, OutputCollector<BytesWritable, BytesWritable>, Reporter) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormatCombiner
 
reduce(BytesWritable, Iterator<BytesWritable>, OutputCollector<BytesWritable, BytesWritable>, Reporter) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
REDUCER_CLOSED_COUNT_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
REDUCER_SPECULATIVE_EXECUTION_ENABLE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
REDUNDANT_LOGGING_FILTER - Static variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
REDUNDANT_LOGGING_FILTER - Static variable in class com.linkedin.venice.router.streaming.VeniceChunkedResponse
 
RedundantExceptionFilter - Class in com.linkedin.venice.utils
 
RedundantExceptionFilter() - Constructor for class com.linkedin.venice.utils.RedundantExceptionFilter
 
RedundantExceptionFilter(int, long) - Constructor for class com.linkedin.venice.utils.RedundantExceptionFilter
 
refCnt() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
refCnt() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
refCnt() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
refCnt() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
refCnt() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
refCnt() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
Returns the reference count of this object.
ReferenceCounted<T> - Class in com.linkedin.venice.utils
 
ReferenceCounted(T, Consumer<T>) - Constructor for class com.linkedin.venice.utils.ReferenceCounted
 
ReflectUtils - Class in com.linkedin.venice.utils
Utilities for reflection TODO This class may not be needed if we decide to proceed with Guice library for reflections and need to be discarded then
ReflectUtils() - Constructor for class com.linkedin.venice.utils.ReflectUtils
 
refresh() - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
 
refresh() - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
This method will be triggered periodically to keep the store/schema information up-to-date.
refresh() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
 
refresh() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
This method is used to add listener after HelixManager being connected.
refresh() - Method in class com.linkedin.venice.helix.HelixExternalViewRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixLiveInstanceMonitor
Must be run during service start else it wont subscribe to state changes.
refresh() - Method in class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
Refer to HelixReadOnlySchemaRepository.clear() This function will clear the local cache/watches, and populates the schemaMap from schemaRepository.
refresh() - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
 
refresh() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
refresh() - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
refresh() - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
refresh() - Method in class com.linkedin.venice.helix.StoragePersonaRepository
Clears the cache and re-loads the cache data from Zookeeper.
refresh() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
refresh() - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
refresh() - Method in class com.linkedin.venice.router.RouterServer
 
refresh() - Method in interface com.linkedin.venice.VeniceResource
 
REFRESH_ATTEMPTS_FOR_ZK_RECONNECT - Static variable in class com.linkedin.venice.ConfigKeys
 
REFRESH_INTERVAL_FOR_ZK_RECONNECT_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
refreshAndUpdatePushStatus(String, ExecutionStatus, Optional<String>) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
refreshAndUpdatePushStatus(String, ExecutionStatus, Optional<String>) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Here, we refresh the push status, in order to avoid a race condition where a small job could already be completed.
refreshAndUpdatePushStatus(String, ExecutionStatus, Optional<String>) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
refreshOneStore(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
refreshOneStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
refreshOneStore(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
refreshOneStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
refreshOneStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
Only zk shared system store can be refreshed here, otherwise VeniceException will be thrown.
refreshOneStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
refreshOneStore(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Selective refresh operation which fetches one store from ZK
regionMatches(boolean, int, CharSequence, int, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string and compares the specified range of characters to determine if they are the same.
regionMatches(int, CharSequence, int, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string and compares the specified range of characters to determine if they are the same.
regionMatches(CharSequence, boolean, int, CharSequence, int, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
This methods make regionMatches operation correctly for any chars in strings
regionMatchesAscii(CharSequence, boolean, int, CharSequence, int, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
This is optimized version of regionMatches for string with ASCII chars only
RegionPushDetails - Class in com.linkedin.venice.meta
 
RegionPushDetails() - Constructor for class com.linkedin.venice.meta.RegionPushDetails
 
RegionPushDetails(String) - Constructor for class com.linkedin.venice.meta.RegionPushDetails
 
RegionPushDetailsResponse - Class in com.linkedin.venice.controllerapi
 
RegionPushDetailsResponse() - Constructor for class com.linkedin.venice.controllerapi.RegionPushDetailsResponse
 
RegionPushDetailsResponse(RegionPushDetails) - Constructor for class com.linkedin.venice.controllerapi.RegionPushDetailsResponse
 
REGIONS_FILTER - com.linkedin.venice.Arg
 
REGIONS_FILTER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
regionsFilter - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
regionsFilter - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
regionsFilter - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
regionsFilter - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
A list of regions that will be impacted by the RollbackCurrentVersion command
regionsFilter - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
A list of regions that will be impacted by the RollForwardCurrentVersion command
regionsFilter - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
A list of regions that will be impacted by the UpdateStore command
RegionUtils - Class in com.linkedin.venice.utils
 
RegionUtils() - Constructor for class com.linkedin.venice.utils.RegionUtils
 
register() - Method in class com.linkedin.venice.d2.D2Server
 
register() - Method in interface com.linkedin.venice.servicediscovery.ServiceDiscoveryAnnouncer
Register the instance with the service discovery system.
register(Channel) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
register(ChannelPromise) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
register(Channel, ChannelPromise) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
register(String) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
register(String, T) - Method in interface com.linkedin.venice.utils.PathResourceRegistry
 
register(String, T) - Method in class com.linkedin.venice.utils.TrieBasedPathResourceRegistry
 
register(R) - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Register a ShutdownableResource resource with this ResourceRegistry.
register(R) - Method in class com.linkedin.alpini.base.test.ResourceRegistryTestBase
 
registerAdminConsumptionCheckpointOffset() - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
Lazily register the checkpoint offset metric after knowing the latest checkpoint offset, so that restarting the controller node will not result in the metric value dipping to 0.
registerAllExtensions(ExtensionRegistry) - Static method in class com.linkedin.venice.protocols.VeniceReadServiceOuterClass
 
registerAllExtensions(ExtensionRegistryLite) - Static method in class com.linkedin.venice.protocols.VeniceReadServiceOuterClass
 
registerConditionalStats() - Method in class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
 
registerConditionalStats() - Method in class com.linkedin.davinci.stats.IngestionStatsReporter
 
registerConditionalStats() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
registerConditionalStats() - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
registerConditionalStats(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
registeredSegment() - Method in class com.linkedin.venice.kafka.validation.Segment
 
registerFactory(Class<F>, F) - Static method in class com.linkedin.alpini.base.registry.ResourceRegistry
Register the factory with the ResourceRegistry such that future invocations of ResourceRegistry.factory(Class) will return an appropiate proxy for the factory.
registerHandler(Class<T>, StatusMessageHandler<T>) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
registerHandler(Class<T>, StatusMessageHandler<T>) - Method in interface com.linkedin.venice.status.StatusMessageChannel
Register a handler to handle a specific message type.
registerLatencySensor(String, Function<DIVStats, WritePathLatencySensor>) - Method in class com.linkedin.davinci.stats.DIVStatsReporter
 
registerLiveInstanceChangedListener(LiveInstanceChangedListener) - Method in class com.linkedin.venice.helix.HelixLiveInstanceMonitor
 
registerLiveInstanceChangedListener(LiveInstanceChangedListener) - Method in interface com.linkedin.venice.meta.LiveInstanceMonitor
 
registerOnlyTotalRate(String, AbstractVeniceStats, Supplier<LongAdderRateGauge>, Time) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
Only register sensor for total stats.
registerPartition(String, RocksDBStoragePartition) - Method in class com.linkedin.davinci.stats.RocksDBMemoryStats
 
registerPerStoreAndTotalSensor(String, AbstractVeniceStats, Supplier<Sensor>, MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
Register sensor for both total and per store stats.
registerRepairTask(StoreIngestionTask, Runnable) - Method in class com.linkedin.davinci.kafka.consumer.RemoteIngestionRepairService
 
registerRouter(String) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
Create a ephemeral ZNode for the give router.
registerRouter(String) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Register the given router instance into the cluster.
registerSensor(NamedMeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
 
registerSensor(NamedMeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensor(String, MeasurableStat...) - Method in class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
registerSensor(String, MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
By default, this function will prepend the request type to the sensor name.
registerSensor(String, MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensor(String, MetricConfig, Sensor[], MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
N.B.: This function is private because it requires the full sensor name, which should be generated from AbstractVeniceStats.getSensorFullName(String), and is therefore less user-friendly for developers of subclasses.
registerSensor(String, Sensor[], MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
 
registerSensor(String, Sensor[], MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensorAttributeGauge(String, String, AsyncGauge) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensorIfAbsent(NamedMeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensorIfAbsent(String, MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensorIfAbsent(String, String, MetricConfig, Sensor[], MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensorWithAggregate(String, MetricConfig, Supplier<MeasurableStat[]>) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensorWithAggregate(String, Supplier<MeasurableStat[]>) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
registerSensorWithDetailedPercentiles(String, MeasurableStat...) - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
By default, this function will prepend the request type to the sensor name, and register percentiles with the same name.
registerSerializer(String, VeniceSerializer) - Method in class com.linkedin.venice.helix.HelixAdapterSerializer
 
registerServingCache(VeniceStoreCache) - Method in class com.linkedin.davinci.store.cache.backend.StoreCacheStats
 
registerSslHandshakeSensors(SslInitializer) - Method in class com.linkedin.venice.router.stats.SecurityStats
 
registerStats() - Method in class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
 
registerStats() - Method in class com.linkedin.davinci.stats.DIVStatsReporter
 
registerStats() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStatReporter
 
registerStats() - Method in class com.linkedin.davinci.stats.IngestionStatsReporter
 
registerStoreDataChangedListener(StoreDataChangedListener) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
registerStoreDataChangedListener(StoreDataChangedListener) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
registerStoreDataChangedListener(StoreDataChangedListener) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
registerStoreDataChangedListener(StoreDataChangedListener) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Register store data change listener.
registerTransformerErrorSensor() - Method in class com.linkedin.davinci.stats.IngestionStats
 
registerTransformerErrorSensor(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
registerTransformerLatencySensor() - Method in class com.linkedin.davinci.stats.IngestionStats
 
registerTransformerLatencySensor(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
registerTransportClient(ClientConfig, TransportClient) - Static method in class com.linkedin.venice.client.store.ClientFactoryTestUtils
 
REGISTRY_THREAD_LOCAL - Static variable in class com.linkedin.alpini.base.test.ResourceRegistryTestBase
 
REGULAR - com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
 
REGULAR_VERSION_ETL_ENABLED - com.linkedin.venice.Arg
 
REGULAR_VERSION_ETL_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
regularVersionETLEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
regularVersionETLEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
regularVersionETLEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Whether or not enable regular version ETL for this store.
reinitDeflator() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
reinitDeflator() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
REJECT_STRATEGY - Static variable in class com.linkedin.venice.throttle.EventThrottler
 
RelayNotifier - Class in com.linkedin.davinci.notifier
RelayNotifier is a VeniceNotifier which takes in a target VeniceNotifier and forward all actions to the target notifier.
RelayNotifier(VeniceNotifier) - Constructor for class com.linkedin.davinci.notifier.RelayNotifier
 
release() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
release() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
release() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
release() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
release() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
release() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
Decreases the reference count by 1 and deallocates this object if the reference count reaches at 0.
release() - Method in class com.linkedin.venice.utils.ReferenceCounted
 
release(int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
release(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
release(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
release(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
release(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
release(int) - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
Decreases the reference count by the specified decrement and deallocates this object if the reference count reaches at 0.
release(ControllerClient) - Static method in class com.linkedin.venice.controllerapi.ControllerClientFactory
 
release(D2ControllerClient) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
 
release(Channel) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
Release the channel to the pool.
release(Channel) - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
release(Channel) - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
 
release(Channel) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
release(Channel) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
release(Channel) - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
release(Channel, Promise<Void>) - Method in class com.linkedin.alpini.netty4.pool.EspressoFixedChannelPool
 
release(Channel, Promise<Void>) - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
 
release(Channel, Promise<Void>) - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
release(Channel, Promise<Void>) - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
release(Channel, Promise<Void>) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
release(Channel, Promise<Void>) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
release(Channel, Promise<Void>) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
release(String) - Static method in class com.linkedin.venice.d2.D2ClientFactory
 
release(String) - Method in class com.linkedin.venice.utils.SharedObjectFactory
A method to notify to the factory that the user of the object no longer needs it.
release(T) - Method in interface com.linkedin.alpini.base.pool.AsyncPool
 
release(T) - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
release0(T) - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
releaseAndFailAll(ChannelOutboundInvoker, Throwable) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Release all buffers in the queue and complete all listeners and promises.
releaseConnectSemaphore() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
releaseHealthCheck() - Method in class com.linkedin.alpini.netty4.pool.EspressoSimpleChannelPool
Indicates whether this pool will check the health of channels before offering them back into the pool.
releaseHealthCheck() - Method in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
Indicates whether this pool will check the health of channels before offering them back into the pool.
releaseLatch() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
releaseRequest(BHS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
releaseRequest(BasicFullHttpRequest) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
releaseResponse(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
releaseResponse(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
releaseTargetPortBinding(int) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
releaseTargetPortBinding aims to release the target port by killing lingering ingestion process bound to the port, which is created from previous deployment and was not killed due to unexpected failures.
remainingCapacity() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
Returns Integer.MAX_VALUE because this is an unbounded queue.
remainingCapacity() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
remainingMemoryCapacityInByte() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
REMOTE_KAFKA_BOOTSTRAP_SERVERS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
RemoteIngestionRepairService - Class in com.linkedin.davinci.kafka.consumer
Singleton class meant to keep track of subscription failures for ingestion tasks where the ingestion task needs to keep running despite cluster failures.
RemoteIngestionRepairService(int) - Constructor for class com.linkedin.davinci.kafka.consumer.RemoteIngestionRepairService
 
removableResult(String) - Static method in class com.linkedin.venice.controller.NodeRemovableResult
 
remove() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Retrieves and removes the head (first element) of this list.
remove() - Method in class com.linkedin.alpini.base.misc.SoftThreadLocal
Removes the current thread's value for this thread-local variable.
remove() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
remove(int) - Method in class com.linkedin.venice.utils.SparseConcurrentList
A function which behaves like Map.remove(Object), rather than List.remove(int), in the sense that it removes the item from the collection, returns the previous value (if any), but *does not* shift subsequent items to the left (as the regular List.remove(int) would.
remove(int) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
remove(ByteBufAllocator, int, ChannelPromise) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Remove a ByteBuf from the queue with the specified number of bytes.
remove(CharSequence) - Method in interface com.linkedin.alpini.base.misc.Headers
 
remove(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
remove(CharSequence) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
remove(Object) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
remove(Object) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
remove(Object) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Removes the first occurrence of the specified element from this list, if it is present.
remove(Object) - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool.PoolChannelGroup
 
remove(Object) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl.FixedPoolChannelGroup
 
remove(Object) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
remove(Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
Removes the mapping for the specified key from this map if present.
remove(Object) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
remove(Object) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
remove(Object, Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
remove(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
remove(String) - Method in class com.linkedin.venice.pubsub.api.EmptyPubSubMessageHeaders
 
remove(String) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
 
remove(ZkBaseDataAccessor<T>, String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
remove(ZkBaseDataAccessor<T>, String, int) - Static method in class com.linkedin.venice.utils.HelixUtils
 
remove(R) - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Removes the specified ShutdownableResource from this ResourceRegistry.
remove(T) - Method in class com.linkedin.venice.utils.ExpiringSet
 
REMOVE_DERIVED_SCHEMA - com.linkedin.venice.Command
 
REMOVE_DERIVED_SCHEMA - com.linkedin.venice.controllerapi.ControllerRoute
 
REMOVE_FROM_STORE_ACL - com.linkedin.venice.Command
 
REMOVE_NODE - com.linkedin.venice.Command
 
REMOVE_NODE - com.linkedin.venice.controllerapi.ControllerRoute
 
REMOVE_PARTITION - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
REMOVE_STORAGE_ENGINE - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
REMOVE_STORE_FROM_GRAVEYARD - com.linkedin.venice.controllerapi.ControllerRoute
 
REMOVE_VIEW - com.linkedin.venice.Arg
 
removeAce(Resource, AceEntry) - Method in interface com.linkedin.venice.authorization.AuthorizerService
This will remove a single AceEntry from the existing AceEntries for a resource.
removeAce(Resource, AceEntry) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
removeAceEntry(AceEntry) - Method in class com.linkedin.venice.authorization.AclBinding
Remove one AceEntry from the existing list of Aces.
removeAcl(String) - Method in interface com.linkedin.venice.acl.DynamicAccessController
Remove a resource from the resource list.
removeActiveTimestampsLowerOrEqualTo(long) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
removeAll(ComplementSet<T>) - Method in class com.linkedin.venice.utils.ComplementSet
 
removeAll(Collection<?>) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
removeAll(Collection<?>) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
removeAll(Collection<?>) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
removeAll(Collection<?>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
removeAllLocks() - Method in class com.linkedin.venice.utils.locks.ResourceAutoClosableLockManager
 
removeAllSchemas() - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
removeAvroIllegalCharacter(String) - Static method in class com.linkedin.venice.compute.ComputeUtils
According to Avro specification (https://avro.apache.org/docs/1.7.7/spec.html#Names): The name portion of a fullname, record field names, and enum symbols must: 1.
removeByIndex(int) - Method in class com.linkedin.davinci.utils.IndexedHashMap
O(N) in the worst case.
removeByIndex(int) - Method in interface com.linkedin.davinci.utils.IndexedMap
 
removeByIndex(int) - Method in interface com.linkedin.venice.utils.IndexedMap
 
removeConnectionPoolManager(PoolingNHttpClientConnectionManager) - Method in class com.linkedin.venice.stats.HttpConnectionPoolStats
 
removeContext(LoggerContext) - Method in class com.linkedin.alpini.log.FastLogContextFactory
 
removeCustomizedState() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
remove customized state for this partition if there is one
removeDeletionInfoWithTimestampsLowerOrEqualTo(long) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
removeDerivedSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
 
removeDerivedSchema(String, int, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
removeDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
removeDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
removeDerivedSchema(String, int, int) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
Remove an existing derived schema
removeDerivedSchema(String, String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
removeDerivedSchema(String, String, int, int) - Method in interface com.linkedin.venice.controller.Admin
Remove an existing derived schema
removeDerivedSchema(String, String, int, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
removeDerivedSchema(String, String, int, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
removeEldestEntry(Map.Entry<K, V>) - Method in class com.linkedin.venice.utils.BoundedHashMap
 
removeEmptyValue() - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
The value to return when AbstractCoalescingBufferQueue10294.remove(ByteBufAllocator, int, ChannelPromise) is called but the queue is empty.
removeFirst() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Removes and returns the first element from this list.
removeFirst(ChannelPromise) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Remove the first ByteBuf from the queue.
removeFirstOccurrence(Object) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Removes the first occurrence of the specified element in this list.
removeFromStorageEngine(int, byte[], Delete) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
removeFromStorageEngine(int, byte[], Delete) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
removeFromSupposedlyOngoingIncrementalPushVersions(String, int, String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
removeHost(H) - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
 
removeIf(Predicate<? super E>) - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
removeIf(Predicate<? super E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
removeInstanceFromAllowList(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
removeInstanceFromAllowList(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Remove the given helix nodeId from the allowlist in ZK.
removeInstanceFromAllowList(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
removeInstanceFromAllowList(String, String) - Method in interface com.linkedin.venice.helix.AllowlistAccessor
Remove the given helix nodeId from the allowlist in ZK.
removeInstanceFromAllowList(String, String) - Method in class com.linkedin.venice.helix.ZkAllowlistAccessor
Remove the given helix nodeId from the allowlist in ZK.
removeLagMonitor(Version, int) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
Removes monitoring for a partition of a given version.
removeLast() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Removes and returns the last element from this list.
removeLastNewLine(StringBuilder) - Static method in class com.linkedin.alpini.netty4.misc.HttpToStringUtils
 
removeLastOccurrence(Object) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Removes the last occurrence of the specified element in this list
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
removeListener(GenericFutureListener<? extends Future<? super Void>>) - Method in class io.netty.bootstrap.PendingConnectPromise
 
removeListener(GenericFutureListener<? extends Future<? super V>>) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
removeListener(PropertyKey, Object) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
removeListeners(GenericFutureListener<? extends Future<? super Void>>...) - Method in class io.netty.bootstrap.PendingConnectPromise
 
removeListeners(GenericFutureListener<? extends Future<? super V>>...) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
removeLocalStorageEngine(String) - Method in class com.linkedin.davinci.storage.StorageEngineRepository
 
removeLockForResource(T) - Method in class com.linkedin.venice.utils.locks.ResourceAutoClosableLockManager
 
removeMetaStoreWriter(String) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
This function should be used only for store deletion scenario.
removeMetric(TehutiMetric) - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
 
removeNodeFromAllowList(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
 
removeNodeFromAllowList(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
removeNodeFromCluster(Admin) - Method in class com.linkedin.venice.controller.server.NodesAndReplicas
 
removeNodeFromCluster(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
removePartition(int) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
removePartitionFromStoreGracefully() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
removePartitionIngestionStatus(int) - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
removeProducerPartitionState(GUID) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
removeProperty(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
removePushStatusStoreVeniceWriter(String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
removeQuotes(String) - Static method in class com.linkedin.venice.client.store.QueryTool
 
removeResourceRegistryThreadLocal() - Method in class com.linkedin.alpini.base.test.ResourceRegistryTestBase
 
removeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
removeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
removeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
removeStorageEngine(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.StorageEngineFactory
Remove the storage engine from the underlying storage configuration
removeStorageEngine(String) - Method in interface com.linkedin.davinci.ingestion.DaVinciIngestionBackend
 
removeStorageEngine(String) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
removeStorageEngine(String) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
removeStorageEngine(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
removeStorageEngine(String) - Method in class com.linkedin.davinci.storage.StorageService
 
removeStorageEngine(String) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
removeStorageEngine(String) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
removeStorageEngine(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
Currently, this function doesn't apply any IO throttling and if there is a side effect discovered in the read path in the future, we will need to apply some optimization here.
removeStorageEngine(String) - Method in class com.linkedin.davinci.store.StorageEngineFactory
Remove the storage engine without opening it.
removeStorageEnginePartition(String, int) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
 
removeStorageEnginePartition(String, int) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
 
removeStorageEnginePartition(String, int) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
removeStorageEnginePartition(String, int) - Method in class com.linkedin.davinci.store.StorageEngineFactory
 
removeStorageNode(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
removeStorageNode(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Remove one storage node from the given cluster.
removeStorageNode(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
removeStore(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
removeStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
removeStore(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
removeStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepository
 
removeStoreFromGraveyard(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
removeStoreFromGraveyard(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
removeStoreFromGraveyard(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
removeStoreFromGraveyard(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
removeStoreFromGraveyard(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
removeStoreFromGraveyard(String, String) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
 
removeStoreFromGraveyard(String, String) - Method in interface com.linkedin.venice.meta.StoreGraveyard
Remove the given store from graveyard in the specified cluster.
removeStoreSchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
This function is used to remove schema entry for the given store from local cache, and related listeners as well.
removeTopicPartition(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
removeTopicPartitionFromConsumptionTask(PubSubConsumerAdapter, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
removeTrackedOffsets(TopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
Remove tracked offsets state of a topic partition.
removeValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
 
removeValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
 
removeValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
removeValueSchema(String, int) - Method in interface com.linkedin.venice.meta.ReadWriteSchemaRepository
 
removeVeniceWriter(String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreVeniceWriterCache
 
removeVersion(int) - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
removeVersionSpecificCompressor(String) - Method in class com.linkedin.venice.compression.CompressorFactory
 
reopen() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Reopen the database.
reopen() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
Reopen the underlying RocksDB database, and this operation will unload the data cached in memory.
reopenStoragePartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Reopen the underlying database.
REPAIR - com.linkedin.venice.Arg
 
repartitionAndSortWithinPartitions(Dataset<Row>, Partitioner, Comparator<Row>) - Static method in class com.linkedin.venice.hadoop.spark.utils.SparkPartitionUtils
This function provides the equivalent of JavaPairRDD.repartitionAndSortWithinPartitions(org.apache.spark.Partitioner) in Dataframe API.
replace(char, char) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Copies this string replacing occurrences of the specified character with another character.
replace(ByteBuf) - Method in class com.linkedin.alpini.netty4.http2.Http1FullRequest
replace(ByteBuf) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
replace(ByteBuf) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
replace(ByteBuf) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
replace(ByteBuf) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
replace(ByteBuf) - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
replace(ByteBuf) - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
replace(ByteBuf) - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
replace(Collection<FullHttpMultiPart>) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
replace(Collection<FullHttpMultiPart>) - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
replace(K, V) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
replace(K, V, V) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
replaceAll(BiFunction<? super K, ? super V, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
 
replaceAll(UnaryOperator<E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
replaceAndAddTestIngestionNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
replaceAndAddTestNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
replaceAndAddTestNotifier(VeniceNotifier) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
 
replaceAndAddTestPushStatusNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
replaceAndAddTestPushStatusNotifier(VeniceNotifier) - Method in interface com.linkedin.davinci.ingestion.VeniceIngestionBackend
 
Replica - Class in com.linkedin.venice.helix
Replica is the basic unit to distribute data, replica is belong to a partition and running in a instance.
Replica(Instance, int, String) - Constructor for class com.linkedin.venice.helix.Replica
 
REPLICA - com.linkedin.venice.router.api.VeniceRole
 
ReplicaDetail - Class in com.linkedin.venice.meta
 
ReplicaDetail() - Constructor for class com.linkedin.venice.meta.ReplicaDetail
 
ReplicaDetail(String, String, String) - Constructor for class com.linkedin.venice.meta.ReplicaDetail
 
REPLICAS_OF_STORE - com.linkedin.venice.Command
 
REPLICAS_ON_STORAGE_NODE - com.linkedin.venice.Command
 
REPLICAS_READINESS_ON_STORAGE_NODE - com.linkedin.venice.Command
 
ReplicaState - Class in com.linkedin.venice.routerapi
 
ReplicaState() - Constructor for class com.linkedin.venice.routerapi.ReplicaState
 
ReplicaState(int, String, ExecutionStatus) - Constructor for class com.linkedin.venice.routerapi.ReplicaState
 
ReplicaStatus - Class in com.linkedin.venice.pushmonitor
Class stores replica status and history.
ReplicaStatus(String) - Constructor for class com.linkedin.venice.pushmonitor.ReplicaStatus
 
ReplicaStatus(String, boolean) - Constructor for class com.linkedin.venice.pushmonitor.ReplicaStatus
 
ReplicaStatusSerializerMixin(String) - Constructor for class com.linkedin.venice.helix.PartitionStatusJSONSerializer.ReplicaStatusSerializerMixin
 
REPLICATE_ALL_CONFIGS - com.linkedin.venice.Arg
 
REPLICATE_ALL_CONFIGS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
REPLICATE_META_DATA - com.linkedin.venice.Command
 
REPLICATE_META_DATA - com.linkedin.venice.controllerapi.ControllerRoute
 
replicateAddVersionAndStartIngestion(String, String, String, int, int, Version.PushType, String, long, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
This method is invoked in parent controllers to replicate new version signals for migrating store.
replicateAllConfigs - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
A flag to indicate whether all store configs in parent cluster will be replicated to child clusters; true by default, so that existing UpdateStore messages in Admin topic will behave the same as before.
replicateUpdateStore(String, String, UpdateStoreQueryParams) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
This method is invoked in parent controllers for store migration.
REPLICATION_CHECKPOINT_VECTOR_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.RmdConstants
 
REPLICATION_CHECKPOINT_VECTOR_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.RmdConstants
 
REPLICATION_FACTOR - com.linkedin.venice.Arg
 
REPLICATION_FACTOR - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
REPLICATION_METADATA_COLUMN_FAMILY_INDEX - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
REPLICATION_METADATA_PROTOCOL_VERSION_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
REPLICATION_METADATA_SCHEMA_CREATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
REPLICATION_METADATA_VERSION - Static variable in class com.linkedin.venice.ConfigKeys
This will indicate which ReplicationMetadataSchemaGenerator version to use to generate replication metadata schema.
REPLICATION_METADATA_VERSION_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
REPLICATION_METADATA_VERSION_ID_UNSET - Static variable in interface com.linkedin.venice.meta.Version
Special number indicating no replication metadata version is set.
replicationCheckpointVector - Variable in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
The array which represents where
replicationFactor - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
number of replica each store version will have
replicationFactor - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
The number of replica each store version will keep.
replicationFactor - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
The number of replica this store version is keeping.
replicationMetadataPayload - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
The serialized value of the replication metadata schema.
replicationMetadataPayload - Variable in class com.linkedin.venice.kafka.protocol.Delete
The serialized value of the replication metadata schema.
replicationMetadataPayload - Variable in class com.linkedin.venice.kafka.protocol.Put
The serialized value of the replication metadata schema.
ReplicationMetadataRocksDBStoragePartition - Class in com.linkedin.davinci.store.rocksdb
This ReplicationMetadataRocksDBStoragePartition is built to store key value pair along with the timestamp metadata.
ReplicationMetadataRocksDBStoragePartition(StoragePartitionConfig, RocksDBStorageEngineFactory, String, RocksDBMemoryStats, RocksDBThrottler, RocksDBServerConfig, VeniceStoreVersionConfig) - Constructor for class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
ReplicationMetadataSchemaEntrySerializer - Class in com.linkedin.venice.helix
This class is registered in ZKClient to handle Replication metadata schema serialization.
ReplicationMetadataSchemaEntrySerializer() - Constructor for class com.linkedin.venice.helix.ReplicationMetadataSchemaEntrySerializer
 
replicationMetadataSchemaRepository - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
ReplicationMetadataSchemaRepository - Class in com.linkedin.davinci.consumer
 
ReplicationMetadataSchemaRepository(ControllerClient) - Constructor for class com.linkedin.davinci.consumer.ReplicationMetadataSchemaRepository
 
replicationMetadataVersionId - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
The A/A replication metadata schema version ID that will be used to deserialize replicationMetadataPayload.
replicationMetadataVersionId - Variable in class com.linkedin.venice.kafka.protocol.Delete
The A/A replication metadata schema version ID that will be used to deserialize replicationMetadataPayload.
replicationMetadataVersionId - Variable in class com.linkedin.venice.kafka.protocol.Put
The A/A replication metadata schema version ID that will be used to deserialize replicationMetadataPayload.
replicationMetadataVersionId - Variable in class com.linkedin.venice.meta.StoreInfo
RMD (Replication metadata) version ID on the store-level.
replicationMetadataVersionID - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
RMD (Replication metadata) version ID on the store-level.
replicationMetadataVersionID - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
RMD (Replication metadata) version ID on the store-level.
report() - Method in interface com.linkedin.venice.client.stats.Reporter
 
REPORT - com.linkedin.venice.ingestion.protocol.enums.IngestionAction
 
reportCatchUpVersionTopicOffsetLag(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportCompleted(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportCompleted(PartitionConsumptionState, boolean) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportDataRecoveryCompleted(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportEndOfIncrementalPushReceived(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportEndOfPushReceived(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
Reporter - Interface in com.linkedin.venice.client.stats
 
ReporterBackedMapReduceDataWriterTaskTracker - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.task
An interface to report and retrieve metrics related to data writer tasks during the execution of a MapReduce job.
ReporterBackedMapReduceDataWriterTaskTracker(Reporter) - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
reportError(int, String, Exception) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportError(String, int, Exception) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
reportError(Collection<PartitionConsumptionState>, String, Exception) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportIfCatchUpVersionTopicOffset(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
reportIfCatchUpVersionTopicOffset(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Check if the ingestion progress has reached to the end of the version topic.
reportIngestionStatus(IngestionTaskReport) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionRequestClient
 
reportIngestionStatus(IngestionTaskReport) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
Use executor to execute status reporting in async fashion, otherwise it may cause deadlock between main process and child process.
reportKilled(Collection<PartitionConsumptionState>, VeniceIngestionTaskKilledException) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportLeak(String, int, ByteBuf, Object) - Method in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
reportMetricUpdate(IngestionMetricsReport) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionRequestClient
 
reportProgress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportPushStatus(String, int, ExecutionStatus) - Method in class com.linkedin.davinci.DaVinciBackend
 
reportPushStatus(String, int, ExecutionStatus, Optional<String>) - Method in class com.linkedin.davinci.DaVinciBackend
 
reportQuotaNotViolated(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportQuotaViolated(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportRestarted(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportStarted(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportStartOfIncrementalPushReceived(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportStopped(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportTimestamp - Variable in class com.linkedin.venice.pushstatus.PushStatusValue
heartbeat.
reportTimestamp - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
timestamp for when the reported details were collected
reportTopicSwitchReceived(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
reportType - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
0 => Completed, 1=> Errored, 2 => Started, 3 => Restarted, 4 => Progress, 5 => EndOfPushReceived, 6 => StartOfBufferReplayReceived, 7 => StartOfIncrementalPushReceived, 8 => EndOfIncrementalPushReceived, 9 => TopicSwitchReceived, 10 => DataRecoveryCompleted, 11 => Stopped
reportUnderReplicatedPartition(String, int) - Method in class com.linkedin.venice.controller.stats.AggPartitionHealthStats
 
REPROCESSING_TOPIC - com.linkedin.venice.pubsub.api.PubSubTopicType
 
REPUSH_TTL_ENABLE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config to control the TTL behaviors in repush.
REPUSH_TTL_FILTER_COUNT_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
REPUSH_TTL_POLICY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
REPUSH_TTL_SECONDS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
REPUSH_TTL_START_TIMESTAMP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
RepushInfo - Class in com.linkedin.venice.controllerapi
 
RepushInfo() - Constructor for class com.linkedin.venice.controllerapi.RepushInfo
 
repushInfoResponse - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
RepushInfoResponse - Class in com.linkedin.venice.controllerapi
 
RepushInfoResponse() - Constructor for class com.linkedin.venice.controllerapi.RepushInfoResponse
 
repushTTLEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
repushTtlFilteredRecordCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
repushTTLStartTimeMs - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
RepushViabilityInfo - Class in com.linkedin.venice.datarecovery.meta
 
RepushViabilityInfo() - Constructor for class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
RepushViabilityInfo.Result - Enum in com.linkedin.venice.datarecovery.meta
 
request(String, ControllerRoute, QueryParams, Class<T>) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
request(String, ControllerRoute, QueryParams, Class<T>, int, byte[]) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
 
REQUEST_BASED_METADATA - com.linkedin.venice.Command
 
REQUEST_TOPIC - com.linkedin.venice.authorization.Method
Custom Methods for Venice Controller.
REQUEST_TOPIC - com.linkedin.venice.controllerapi.ControllerRoute
 
REQUEST_TYPES_SMALL - Static variable in class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
RequestBasedMetadata - Class in com.linkedin.venice.fastclient.meta
Store metadata class that uses the server's endpoint to fetch metadata and keep the local cache up to date.
RequestBasedMetadata(ClientConfig, D2TransportClient) - Constructor for class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
RequestConstants - Class in com.linkedin.venice
Created by mwise on 3/16/16.
RequestContext - Class in com.linkedin.venice.fastclient
This class is used to include all the intermediate fields required for the communication between the different tiers.
RequestContext() - Constructor for class com.linkedin.venice.fastclient.RequestContext
 
requestEncoding(HttpRequest) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
requestEncoding0(HttpRequest) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpContentEncoder
 
RequestHelper - Class in com.linkedin.venice.request
 
RequestHelper() - Constructor for class com.linkedin.venice.request.RequestHelper
 
RequestRetriableChecker<P,​R,​HRS> - Interface in com.linkedin.alpini.router.api
 
requestStorageNode(String) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
requestTimeout(Function<Headers, Long>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
requestTopic() - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
This function should return a VersionCreationResponse to determine the PubSub topic and the characteristics that the producer should follow.
requestTopic() - Method in class com.linkedin.venice.producer.online.OnlineVeniceProducer
 
requestTopicForPushing(Admin) - Method in class com.linkedin.venice.controller.server.CreateVersion
Instead of asking Venice to create a version, pushes should ask venice which topic to write into.
requestTopicForWrites(String, long, Version.PushType, String, boolean, boolean, boolean, Optional<String>, Optional<String>, Optional<String>, boolean, long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
requestTopicForWrites(String, long, Version.PushType, String, boolean, boolean, boolean, Optional<String>, Optional<String>, Optional<String>, boolean, long, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
requestTopicForWrites(String, long, Version.PushType, String, boolean, boolean, boolean, Optional<String>, Optional<String>, Optional<String>, boolean, long, boolean, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
Request a topic for the VeniceWriter to write into.
RequestType - Enum in com.linkedin.venice.read
 
REQUIRED_SECRET_KEY_COUNT - Static variable in class com.linkedin.venice.hadoop.ssl.UserCredentialsFactory
 
requireNotEmpty(String) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
requireNotEmpty(String, String) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
 
reset() - Method in class com.linkedin.alpini.base.concurrency.ComplexAccumulator
Resets variables maintaining the sum to zero.
reset() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
Resets variables maintaining the sum to zero.
reset() - Method in class com.linkedin.alpini.base.concurrency.ThreadedAccumulator
 
reset() - Method in class com.linkedin.alpini.base.hash.Crc32
 
reset() - Method in class com.linkedin.alpini.base.hash.Crc32C
 
reset() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
reset() - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
reset() - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
reset() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
reset() - Method in class com.linkedin.alpini.base.statistics.Welfords
 
reset() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
Resets the state of the decoder so that it is ready to decode a new message.
reset() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
reset() - Method in class com.linkedin.venice.compression.ReusableGzipOutputStream
 
reset() - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
Called when the state model is reset.
reset() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
Reset the checksum generator
reset() - Method in interface com.linkedin.venice.utils.lazy.LazyResettable
Returns to the uninitialized state.
reset() - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
 
reset() - Method in class com.linkedin.venice.utils.lazy.LazyResettableWithTearDown
 
RESET_OFFSET - com.linkedin.davinci.kafka.consumer.ConsumerActionType
 
RESET_PARTITION - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
resetContext() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
resetDeflator() - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
resetDeflator() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
resetExpectedChecksum() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
resetIngestionTaskPushTimeoutGauge(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
resetInternal() - Method in class com.linkedin.venice.kafka.validation.checksum.Adler32CheckSum
 
resetInternal() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
resetInternal() - Method in class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
 
resetInternal() - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
 
resetOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
resetOffset(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Resets the offset for a specific topic-partition, seeking it to the beginning of the topic.
resetOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
resetPartition(String, String, String, List<String>) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Reset a list of partitions in error state for an instance.
resetPartition(String, String, String, List<String>) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
resetPartitionConsumptionOffset(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Adds an asynchronous resetting partition consumption offset request for the task.
resetProcessedRecordSizeSinceLastSync() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
resetTopicPartition(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
resetTransportClientProvider() - Static method in class com.linkedin.venice.client.store.ClientFactoryTestUtils
 
resetUnitTestMode() - Static method in class com.linkedin.venice.client.store.ClientFactoryTestUtils
 
resetUnitTestMode() - Static method in class com.linkedin.venice.d2.D2ClientFactory
 
resetUpstreamOffsetMap(Map<String, Long>) - Method in class com.linkedin.venice.offsets.OffsetRecord
Reset the checkpoint upstream offset map to another map provided as the input.
resolve(String) - Method in class com.linkedin.venice.httpclient.CachedDnsResolver
 
resolve(InetSocketAddress, Promise<InetSocketAddress>) - Method in class com.linkedin.alpini.netty4.pool.BasicDnsResolver
 
resolve(InetSocketAddress, Promise<InetSocketAddress>) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolResolver
Asynchronously resolves the supplied InetSocketAddress and completes the promise when done.
ResolveAllBootstrap - Class in io.netty.bootstrap
The existing Netty Bootstrap has a limitation regarding connecting to remote hosts where the hostname resolves to more than one IP address.
ResolveAllBootstrap(CallTracker, CallTracker) - Constructor for class io.netty.bootstrap.ResolveAllBootstrap
Constructor for the bootstrap.
ResolveAllBootstrap(ResolveAllBootstrap) - Constructor for class io.netty.bootstrap.ResolveAllBootstrap
 
ResolveAllBootstrap(Function<SocketAddress, CallTracker>, Function<SocketAddress, CallTracker>) - Constructor for class io.netty.bootstrap.ResolveAllBootstrap
Constructor for the bootstrap
resolveSourceKafkaServersWithinTopicSwitch(TopicSwitch) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Applies name resolution to all Kafka URLs in the provided TopicSwitch.
Resource - Class in com.linkedin.venice.authorization
Represents a resource identified by "name".
Resource(String) - Constructor for class com.linkedin.venice.authorization.Resource
 
RESOURCE_NOT_FOUND - com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
 
RESOURCE_STILL_EXISTS - com.linkedin.venice.exceptions.ErrorType
 
resourceAssignment - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
ResourceAssignment - Class in com.linkedin.venice.helix
Assignments for all of resources.
ResourceAssignment() - Constructor for class com.linkedin.venice.helix.ResourceAssignment
 
ResourceAssignment.ResourceAssignmentChanges - Class in com.linkedin.venice.helix
 
ResourceAutoClosableLockManager<T> - Class in com.linkedin.venice.utils.locks
This class maintains a map from resource of a certain type to its lock.
ResourceAutoClosableLockManager(Supplier<Lock>) - Constructor for class com.linkedin.venice.utils.locks.ResourceAutoClosableLockManager
 
resourceName - Variable in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
RESOURCENAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceClientRequest
 
ResourcePath<K> - Interface in com.linkedin.alpini.router.api
 
ResourcePathParser<P extends ResourcePath<K>,​K> - Interface in com.linkedin.alpini.router.api
 
ResourceReadUsageTracker - Interface in com.linkedin.venice.cleaner
This interface defines the API to track the read usage per resource.
resourceRegistry(ResourceRegistry) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
resourceRegistry(ResourceRegistry) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
ResourceRegistry - Class in com.linkedin.alpini.base.registry
A registry to manage Shutdownable resources.
ResourceRegistry() - Constructor for class com.linkedin.alpini.base.registry.ResourceRegistry
Construct a ResourceRegistry class instance.
ResourceRegistry(boolean) - Constructor for class com.linkedin.alpini.base.registry.ResourceRegistry
Construct a ResourceRegistry class instance.
ResourceRegistry.Factory<R extends ShutdownableResource> - Interface in com.linkedin.alpini.base.registry
Factories must implement this interface.
ResourceRegistry.ShutdownFirst - Interface in com.linkedin.alpini.base.registry
Resources which implement ResourceRegistry.ShutdownFirst will be shut down during the first phase.
ResourceRegistry.ShutdownLast - Interface in com.linkedin.alpini.base.registry
Resources which implement ResourceRegistry.ShutdownLast will be shut down during the last phase.
ResourceRegistry.Sync - Interface in com.linkedin.alpini.base.registry
Resources which implement ResourceRegistry.Sync will be shut down after preceding resources have finished shutting down and further resources will shut down after it has completed shutting down.
ResourceRegistryTestBase - Class in com.linkedin.alpini.base.test
 
ResourceRegistryTestBase() - Constructor for class com.linkedin.alpini.base.test.ResourceRegistryTestBase
 
ResourceStateResponse - Class in com.linkedin.venice.routerapi
 
ResourceStateResponse() - Constructor for class com.linkedin.venice.routerapi.ResourceStateResponse
 
ResourceStillExistsException - Exception in com.linkedin.venice.exceptions
 
ResourceStillExistsException(String) - Constructor for exception com.linkedin.venice.exceptions.ResourceStillExistsException
 
responseAggregatorFactory(ResponseAggregatorFactory<HTTP_REQUEST, HTTP_RESPONSE>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
ResponseAggregatorFactory<BASIC_HTTP_REQUEST extends BasicRequest,​HTTP_RESPONSE> - Interface in com.linkedin.alpini.router.api
Created by acurtis on 6/19/17.
responseMetrics(Headers) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
responseMetrics(Function<Headers, Metrics>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
ResponseOutOfSequence(String) - Constructor for exception com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.ResponseOutOfSequence
 
RESPONSERCU_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
 
responseStatus() - Method in exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
restarted(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Consumption is restarted from given offset for a store and partition
restarted(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
restarted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
restarted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
restarted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
restarted(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
RESTARTED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
RESTARTED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
restore() - Static method in enum com.linkedin.alpini.base.misc.Time
 
restoreAllThrottlers() - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
restoreStoragePartitions() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
restoreStoragePartitions(boolean, boolean) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Load the existing storage partitions.
restoreSystemExit() - Static method in class com.linkedin.venice.utils.TestUtils
 
Result() - Constructor for class com.linkedin.venice.datarecovery.Command.Result
 
Result() - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
Result() - Constructor for class com.linkedin.venice.datarecovery.MonitorCommand.Result
 
Result() - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
 
Result(Long) - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
Result(String) - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
RESULT_SCHEMA_CACHE - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
resultFieldName - Variable in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
The field name used to store the calculated result
resultFieldName - Variable in class com.linkedin.venice.compute.protocol.request.Count
The field name used to store the count operation result
resultFieldName - Variable in class com.linkedin.venice.compute.protocol.request.DotProduct
The field name used to store the calculated result
resultFieldName - Variable in class com.linkedin.venice.compute.protocol.request.HadamardProduct
The field name used to store the calculated result
resultSchemaName - Variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
resultSchemaStr - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequest
The field contains the serialized result schema, which will be used to de-serialize the response returned by Venice
resultSchemaStr - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
The field contains the serialized result schema, which will be used to de-serialize the response returned by Venice
resultSchemaStr - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
The field contains the serialized result schema, which will be used to de-serialize the response returned by Venice
resultSchemaStr - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
The field contains the serialized result schema, which will be used to de-serialize the response returned by Venice
resultSchemaStr - Variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
The field contains the serialized result schema, which will be used to de-serialize the response returned by Venice
resume() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Pause the client on all subscriptions.
resume() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
resume(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
If the partitions were not previously paused or if they were not subscribed at all, this method is a no-op.
resume(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Resumes message consumption for the specified PubSub topic-partition.
resume(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
resume(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Resume the client on all or subset of partitions this client is subscribed to and has paused.
resume(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
RESUME - com.linkedin.davinci.kafka.consumer.ConsumerActionType
 
ResumeStore - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
ResumeStore() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
Default constructor.
ResumeStore(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
All-args constructor.
resumeTransfer() - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
Continues to fetch the chunks from the input.
retain() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
retain() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
retain() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
retain() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
retain() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
retain() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
retain() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
retain() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
retain() - Method in class com.linkedin.venice.utils.ReferenceCounted
 
retain(int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
retain(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
retain(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
retain(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
retain(int) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
retain(int) - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
retain(int) - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
retain(int) - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
retainAll(Collection<?>) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
retainAll(Collection<?>) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
retainAll(Collection<?>) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
retainAll(Collection<?>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
retainedDuplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
retainedDuplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
retainedDuplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
retainedDuplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
retainedDuplicate() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
retainedDuplicate() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
retainedDuplicate() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
retainRequest(BHS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
retainRequest(BasicFullHttpRequest) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
retentionInMs() - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
retireOldErrorPushes(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
retireOldStoreVersions(String, String, boolean, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
For a given store, determine its versions to delete based on the BackupStrategy settings and execute the deletion in the cluster (including all its resources).
retireOldStoreVersions(String, String, boolean, int) - Method in interface com.linkedin.venice.meta.StoreCleaner
 
RetriableAvroGenericStoreClient<K,​V> - Class in com.linkedin.venice.fastclient
This class is mostly used to trigger retry in the following scenarios: 1.
RetriableAvroGenericStoreClient(InternalAvroStoreClient<K, V>, ClientConfig, TimeoutProcessor) - Constructor for class com.linkedin.venice.fastclient.RetriableAvroGenericStoreClient
 
RetriableAvroSpecificStoreClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient
 
RetriableAvroSpecificStoreClient(InternalAvroStoreClient<K, V>, ClientConfig, TimeoutProcessor) - Constructor for class com.linkedin.venice.fastclient.RetriableAvroSpecificStoreClient
 
RetriableStoreClient<K,​V> - Class in com.linkedin.venice.client.store
TODO: make retry work for compute request.
RetriableStoreClient(StatTrackingStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.client.store.RetriableStoreClient
 
retrievePushStatus(String, StoreInfo) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
retrieveVersionsToDelete(int) - Method in class com.linkedin.venice.meta.AbstractStore
 
retrieveVersionsToDelete(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
retrieveVersionsToDelete(int) - Method in interface com.linkedin.venice.meta.Store
 
RETRY - com.linkedin.venice.Arg
 
RETRY_ABORTED_BY_NO_AVAILABLE_REPLICA - com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
 
retryableRequest(int, Function<ControllerClient, R>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
retryableRequest(int, Function<ControllerClient, R>, Function<R, Boolean>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
retryableRequest(C, int, Function<C, R>) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
Useful for pieces of code which want to have a test mocking the result of the function that's passed in...
retryableRequest(C, int, Function<C, R>, Function<R, Boolean>) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
 
RetryCounter - Class in com.linkedin.alpini.base.misc
A non-thread safe counter that should be used and increased in a single thread env when the increment is called
RetryCounter() - Constructor for class com.linkedin.alpini.base.misc.RetryCounter
 
RetryCountSlidingWindow - Class in com.linkedin.alpini.base.misc
A Sliding Window implementation that is implemented as followed: 1.
RetryCountSlidingWindow(int, int, ScheduledExecutorService) - Constructor for class com.linkedin.alpini.base.misc.RetryCountSlidingWindow
 
RetryManager - Class in com.linkedin.venice.fastclient.meta
This class offers advanced client retry behaviors.
RetryManager(MetricsRepository, String, long, double) - Constructor for class com.linkedin.venice.fastclient.meta.RetryManager
 
RetryManager(MetricsRepository, String, long, double, Clock) - Constructor for class com.linkedin.venice.fastclient.meta.RetryManager
 
RetryManagerStats - Class in com.linkedin.venice.fastclient.stats
 
RetryManagerStats(MetricsRepository, String, RetryManager) - Constructor for class com.linkedin.venice.fastclient.stats.RetryManagerStats
 
RetryUtils - Class in com.linkedin.venice.utils
 
RetryUtils.IntermediateFailureHandler - Interface in com.linkedin.venice.utils
 
ReusableGzipOutputStream - Class in com.linkedin.venice.compression
This class implements a stream filter for writing compressed data in the GZIP file format.
ReusableGzipOutputStream(ByteArrayOutputStream) - Constructor for class com.linkedin.venice.compression.ReusableGzipOutputStream
 
reversed(Collection<T>) - Static method in class com.linkedin.venice.utils.CollectionUtils
A reversed copy of the given collection
ReverseHandler - Class in com.linkedin.alpini.netty4.handlers
Reverse the polarity of the streams! Created by acurtis on 6/26/17.
ReverseHandler(ChannelHandler...) - Constructor for class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
ReverseHandler(Supplier<ChannelHandler[]>) - Constructor for class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
REWIND_EPOCH_TIME_BUFFER_IN_SECONDS_OVERRIDE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Relates to the above argument.
REWIND_EPOCH_TIME_IN_SECONDS_OVERRIDE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
A time stamp specified to rewind to before replaying data.
REWIND_FROM_EOP - com.linkedin.venice.meta.BufferReplayPolicy
Default value.
REWIND_FROM_SOP - com.linkedin.venice.meta.BufferReplayPolicy
Replay all records from 'rewindTimeInSeconds' seconds before SOP call was received at the controller.
REWIND_TIME_DECIDED_BY_SERVER - Static variable in class com.linkedin.venice.VeniceConstants
This is a sentinel value to be used in TopicSwitch message rewindStartTimestamp field between controller and server.
REWIND_TIME_IN_SECONDS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
REWIND_TIME_IN_SECONDS_OVERRIDE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
REWIND_TIME_IN_SECONDS_OVERRIDE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Optional.
rewindStartTimestamp - Variable in class com.linkedin.venice.kafka.protocol.TopicSwitch
The creation time of this control message in parent controller minus the rewind time of the corresponding store; leaders in different fabrics will get the offset of the source topic by the same start timestamp and start consuming from there; if timestamp is 0, leader will start consuming from the beginning of the source topic.
rewindTimeInSeconds - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
rewindTimeInSeconds - Variable in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
rewindTimeInSeconds - Variable in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
rewindTimeInSecondsOverride - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
The overridable rewind time config for this specific version of a hybrid store, and if it is not specified, the new version will use the store-level rewind time config
rewindTimeInSecondsOverride - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
RFC1036_DATE_FORMAT - Static variable in enum com.linkedin.alpini.base.misc.DateUtils
 
RFC1123_DATE_FORMAT - Static variable in enum com.linkedin.alpini.base.misc.DateUtils
 
RMD_CHUNKING_ENABLED - com.linkedin.venice.Arg
 
RMD_CHUNKING_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
RMD_SCHEMA_DIR - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
rmdChunkingEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
rmdChunkingEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
rmdChunkingEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether current store supports large replication metadata (typically more than 1MB).
rmdChunkingEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Whether or not large replication metadata are supported (via chunking).
RmdConstants - Class in com.linkedin.venice.schema.rmd
This is an util class that contains constants related to replication metadata.
rmdSchemaDir - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
RmdSchemaEntry - Class in com.linkedin.venice.schema.rmd
This holds the schema to perform conflict resolution on records when samza produces data in active active replication mode.
RmdSchemaEntry(int, int, byte[]) - Constructor for class com.linkedin.venice.schema.rmd.RmdSchemaEntry
 
RmdSchemaEntry(int, int, String) - Constructor for class com.linkedin.venice.schema.rmd.RmdSchemaEntry
 
RmdSchemaEntry(int, int, Schema) - Constructor for class com.linkedin.venice.schema.rmd.RmdSchemaEntry
 
RmdSchemaGenerator - Class in com.linkedin.venice.schema.rmd
This is simply a wrapper class to delegate the actual schema generation to version specific adapter.
RmdSchemaGeneratorV1 - Class in com.linkedin.venice.schema.rmd.v1
This class helps in generating a active-active metadata schema to hold update timestamps and offsets from a value schema of a store .
RmdSchemaGeneratorV1() - Constructor for class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
rmdSchemaMap - Variable in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
RmdSerDe - Class in com.linkedin.davinci.replication.merge
This class is responsible for serialization and deserialization related tasks.
RmdSerDe(StringAnnotatedStoreSchemaCache, int) - Constructor for class com.linkedin.davinci.replication.merge.RmdSerDe
 
RmdSerDe(StringAnnotatedStoreSchemaCache, int, boolean) - Constructor for class com.linkedin.davinci.replication.merge.RmdSerDe
 
RmdTimestampType - Enum in com.linkedin.venice.schema.rmd
Type of the replication metadata timestamp.
RmdUtils - Class in com.linkedin.venice.schema.rmd
Ths class is responsible for deserializing RMDs and extract some information from it.
RmdUtils() - Constructor for class com.linkedin.venice.schema.rmd.RmdUtils
 
RmdVersionId - Class in com.linkedin.venice.schema.rmd
 
RmdVersionId(int, int) - Constructor for class com.linkedin.venice.schema.rmd.RmdVersionId
 
RmdWithValueSchemaId - Class in com.linkedin.davinci.replication
A POJO class that contains 3 things/fields: 1.
RmdWithValueSchemaId() - Constructor for class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
RmdWithValueSchemaId(int, int, GenericRecord) - Constructor for class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
RmdWithValueSchemaId(int, int, GenericRecord, ChunkedValueManifest) - Constructor for class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
ROCKS_DB - com.linkedin.venice.meta.PersistenceType
Persistent storage engine that writes to durable media and maintains an off-heap in-memory index.
rocksDB - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
ROCKSDB_ATOMIC_FLUSH_ENABLED - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_AUTO_TUNED_RATE_LIMITER_ENABLED - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_BLOCK_BASE_FORMAT_VERSION - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_BLOCK_CACHE_COMPRESSED_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Shared block cache for compressed data.
ROCKSDB_BLOCK_CACHE_IMPLEMENTATION - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
the implementation of block cache that the venice server should use.
ROCKSDB_BLOCK_CACHE_SHARD_BITS - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
number of bits to count cache shards, total shard count would be 2 to the power of this number.
ROCKSDB_BLOCK_CACHE_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Shared block cache across all the RocksDB databases.
ROCKSDB_BLOCK_CACHE_STRICT_CAPACITY_LIMIT - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
if set to True, Cache size will strictly stay within set bounds, by allocating space for indexes and metadata within cache size.
ROCKSDB_BLOOM_BITS_PER_KEY - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_BYTES_PER_SYNC - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Comments from rocksdb c++ code: Allows OS to incrementally sync files to disk while they are being written, asynchronously, in the background.
ROCKSDB_DB_OPEN_OPERATION_THROTTLE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Every time, when RocksDB tries to open a database, it will spin up multiple threads to load the file metadata in parallel, and the application could hit the thread limit issue if there are many RocksDB open operations at the same time.
ROCKSDB_ENV_COMPACTION_POOL_SIZE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Thread pool being used by all the RocksDB databases.
ROCKSDB_ENV_FLUSH_POOL_SIZE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Thread pool being used by all the RocksDB databases.
ROCKSDB_HASH_TABLE_RATIO - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_HUGE_PAGE_TLB_SIZE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_LAST_FINISHED_RMD_SST_FILE_NO - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
ROCKSDB_LAST_FINISHED_SST_FILE_NO - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
This field is being stored during offset checkpointing in StoreIngestionTask.
ROCKSDB_LEVEL0_FILE_NUM_COMPACTION_TRIGGER - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
When the number of level-0 SST files reaches level0_slowdown_writes_trigger, writes are stalled.
ROCKSDB_LEVEL0_FILE_NUM_COMPACTION_TRIGGER_WRITE_ONLY_VERSION - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_LEVEL0_SLOWDOWN_WRITES_TRIGGER - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_LEVEL0_SLOWDOWN_WRITES_TRIGGER_WRITE_ONLY_VERSION - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_LEVEL0_STOPS_WRITES_TRIGGER - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_LEVEL0_STOPS_WRITES_TRIGGER_WRITE_ONLY_VERSION - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_MAX_BYTES_FOR_LEVEL_BASE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Max size of level base, and by default the next level size will be 10 times bigger;
ROCKSDB_MAX_FILE_OPENING_THREADS - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Currently, the max file open thread cnt per open operation is 16 by default.
ROCKSDB_MAX_LOG_FILE_NUM - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_MAX_LOG_FILE_SIZE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_MAX_MEMTABLE_COUNT - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Max memtable count per database;
ROCKSDB_MAX_OPEN_FILES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_MAX_TOTAL_WAL_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Max total WAL log size per database;
ROCKSDB_MEM_TABLE_HUGE_PAGE_SIZE_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Page size for huge page for the arena used by the memtable in rocksdb.
ROCKSDB_MEMTABLE_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Max memtable size per database;
ROCKSDB_OPTIONS_COMPACTION_STYLE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Please check CompactionStyle to find all the available options.
ROCKSDB_OPTIONS_COMPRESSION_TYPE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Compression type, and please check this enum class to find out all the available options: CompressionType.
ROCKSDB_OPTIONS_USE_DIRECT_READS - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Ability to use direct IO for disk reads, might yield better performance on Azure disks.
ROCKSDB_OVERHEAD_RATIO_FOR_HYBRID_STORE - Static variable in class com.linkedin.venice.store.rocksdb.RocksDBUtils
With level_compaction_dynamic_level_bytes to be false, the stable LSM structure is not guaranteed, so the maximum overhead could be around 2.111 for hybrid stores.
ROCKSDB_PLAIN_TABLE_FORMAT_ENABLED - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_PUT_REUSE_BYTE_BUFFER - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_READ_ASYNC_IO_ENABLED - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Whether to enable async io in the read path or not.
ROCKSDB_RMD_BLOCK_CACHE_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Shared block cache used by RMD column family across all the RocksDB databases.
ROCKSDB_SEPARATE_RMD_CACHE_ENABLED - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_SET_CACHE_INDEX_AND_FILTER_BLOCKS - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
If set to true, we will put index/filter blocks to the block cache.
ROCKSDB_SST_FILE_BLOCK_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
File block size, and this config has impact to the index size and read performance.
ROCKSDB_STATISTICS_ENABLED - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Whether to enable rocksdb statistics.
ROCKSDB_STORE_INDEX_IN_FILE - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
ROCKSDB_TARGET_FILE_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Target file size, and this will only apply to hybrid store since batch-only push from VPJ is using SSTFileWriter directly.
ROCKSDB_TOTAL_MEMTABLE_USAGE_CAP_IN_BYTES - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
https://github.com/facebook/rocksdb/wiki/Write-Buffer-Manager The total memory usage cap of all the memtables for every RocksDB database.
ROCKSDB_WRITE_QUOTA_BYTES_PER_SECOND - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
Check the following link for more details: https://github.com/facebook/rocksdb/wiki/Rate-Limiter This is used to throttle flush and compaction.
RocksDBBlockCacheImplementations - Enum in com.linkedin.davinci.store.rocksdb
 
RocksDBMemoryStats - Class in com.linkedin.davinci.stats
Class that exposes RocksDB memory consumption stats based on all properties that are made available in https://github.com/facebook/rocksdb/blob/master/include/rocksdb/db.h#L870 Properties exist on a per RockDB database basis (equivalent to a Venice partition).
RocksDBMemoryStats(MetricsRepository, String, boolean) - Constructor for class com.linkedin.davinci.stats.RocksDBMemoryStats
 
RocksDBServerConfig - Class in com.linkedin.davinci.store.rocksdb
 
RocksDBServerConfig(VeniceProperties) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
RocksDBSstFileWriter - Class in com.linkedin.davinci.store.rocksdb
 
RocksDBSstFileWriter(String, int, String, EnvOptions, Options, String, boolean, RocksDBServerConfig, boolean) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
RocksDBStats - Class in com.linkedin.venice.stats
Check TickerType to find more details about RocksDB metrics.
RocksDBStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.RocksDBStats
 
RocksDBStorageEngine - Class in com.linkedin.davinci.store.rocksdb
 
RocksDBStorageEngine(VeniceStoreVersionConfig, RocksDBStorageEngineFactory, String, RocksDBMemoryStats, RocksDBThrottler, RocksDBServerConfig, InternalAvroSpecificSerializer<StoreVersionState>, InternalAvroSpecificSerializer<PartitionState>, boolean) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
RocksDBStorageEngineFactory - Class in com.linkedin.davinci.store.rocksdb
 
RocksDBStorageEngineFactory(VeniceServerConfig) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
RocksDBStorageEngineFactory(VeniceServerConfig, RocksDBMemoryStats, InternalAvroSpecificSerializer<StoreVersionState>, InternalAvroSpecificSerializer<PartitionState>) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
 
RocksDBStoragePartition - Class in com.linkedin.davinci.store.rocksdb
In RocksDBStoragePartition, it assumes the update(insert/delete) will happen sequentially.
RocksDBStoragePartition(StoragePartitionConfig, RocksDBStorageEngineFactory, String, RocksDBMemoryStats, RocksDBThrottler, RocksDBServerConfig, VeniceStoreVersionConfig) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
RocksDBStoragePartition(StoragePartitionConfig, RocksDBStorageEngineFactory, String, RocksDBMemoryStats, RocksDBThrottler, RocksDBServerConfig, List<byte[]>, VeniceStoreVersionConfig) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
RocksDBThrottler - Class in com.linkedin.davinci.store.rocksdb
This class is used to throttle RocksDB operations.
RocksDBThrottler(int) - Constructor for class com.linkedin.davinci.store.rocksdb.RocksDBThrottler
 
RocksDBThrottler.RocksDBSupplier - Interface in com.linkedin.davinci.store.rocksdb
 
RocksDBUtils - Class in com.linkedin.venice.store.rocksdb
 
RocksDBUtils() - Constructor for class com.linkedin.venice.store.rocksdb.RocksDBUtils
 
roleFinder(RoleFinder<ROLE>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
RoleFinder<Role> - Interface in com.linkedin.alpini.router.api
 
ROLL_FORWARD_TO_FUTURE_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
ROLLBACK - com.linkedin.venice.hooks.StoreVersionLifecycleEventOutcome
Rollback to the store-version which was in effect prior to the start of the push job (i.e.
ROLLBACK_CURRENT_VERSION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
ROLLBACK_TO_BACKUP_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
RollbackCurrentVersion - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
RollbackCurrentVersion() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
Default constructor.
RollbackCurrentVersion(CharSequence, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
All-args constructor.
rollbackOnError(Message, NotificationContext, StateTransitionError) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
Stop the consumption once a replica become ERROR.
rollbackOnError(Message, NotificationContext, StateTransitionError) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
Called when error occurs in state transition.
rollbackToBackupVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
Set backup version as current version.
rollbackToBackupVersion(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
rollbackToBackupVersion(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
rollbackToBackupVersion(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
rollbackToBackupVersion(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Set backup version as current version in a child region.
rollbackToBackupVersion(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Set backup version as current version in all child regions.
ROLLFORWARD_CURRENT_VERSION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
RollForwardCurrentVersion - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
RollForwardCurrentVersion() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
Default constructor.
RollForwardCurrentVersion(CharSequence, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
All-args constructor.
rollForwardToFutureVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
rollForwardToFutureVersion(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
rollForwardToFutureVersion(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
rollForwardToFutureVersion(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
rollForwardToFutureVersion(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
rollForwardToFutureVersion(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
round(double, int) - Static method in class com.linkedin.venice.utils.Utils
 
ROUND_ROBIN - com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategyEnum
This strategy will try to distribute the load to each group evenly all the time.
ROUTE_DNS_CACHE_HOST_PATTERN - Static variable in class com.linkedin.venice.ConfigKeys
The host matching the configured host pattern will be cached if ConfigKeys.ROUTER_DNS_CACHE_ENABLED is true.
RouteHttpRequestStats - Class in com.linkedin.venice.router.stats
This class stores the stats for combined all type(SINGLE/MULTI/COMPUTE etc) of Router requests to the HttpAsync client compared to RouteHttpStats which stores only per type stats.
RouteHttpRequestStats(MetricsRepository, StorageNodeClient) - Constructor for class com.linkedin.venice.router.stats.RouteHttpRequestStats
 
RouteHttpStats - Class in com.linkedin.venice.router.stats
 
RouteHttpStats(MetricsRepository, RequestType) - Constructor for class com.linkedin.venice.router.stats.RouteHttpStats
 
Router - Interface in com.linkedin.alpini.router.impl
 
ROUTER - Static variable in class com.linkedin.venice.acl.VeniceComponent
 
ROUTER_ASYNC_START_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable async start in Router startup procedure.
ROUTER_CLIENT_DECOMPRESSION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_CLIENT_RESOLUTION_RETRY_ATTEMPTS - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the maximum number of attempts to resolve a client host name before giving up.
ROUTER_CLIENT_RESOLUTION_RETRY_BACKOFF_MS - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the backoff time between each resolution retry.
ROUTER_CLIENT_SSL_HANDSHAKE_QUEUE_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the queue capacity for the thread pool executor used for ssl handshake between clients and a router.
ROUTER_CLIENT_SSL_HANDSHAKE_THREADS - Static variable in class com.linkedin.venice.ConfigKeys
The number of threads that will be used to perform SSL handshakes between clients and a router.
ROUTER_COMPUTE_FAST_AVRO_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable fast-avro in router;
ROUTER_COMPUTE_TARDY_LATENCY_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_CONNECTION_COUNT_GAUGE - Static variable in class com.linkedin.venice.stats.ServerConnectionStats
 
ROUTER_CONNECTION_LIMIT - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_CONNECTION_REQUEST - Static variable in class com.linkedin.venice.stats.ServerConnectionStats
 
ROUTER_CONNECTION_TIMEOUT - Static variable in class com.linkedin.venice.ConfigKeys
Timeout for building a new connection from router to server
ROUTER_DICTIONARY_PROCESSING_THREADS - Static variable in class com.linkedin.venice.ConfigKeys
Number of threads that the Router will use to wait for dictionary to download from storage nodes and process it.
ROUTER_DICTIONARY_RETRIEVAL_TIME_MS - Static variable in class com.linkedin.venice.ConfigKeys
Maximum time allowed for router to download dictionary from Storage nodes.
ROUTER_DNS_CACHE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable customized dns cache in router or not.
ROUTER_DNS_CACHE_REFRESH_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
Refresh interval of cached dns entries if ConfigKeys.ROUTER_DNS_CACHE_ENABLED is true.
ROUTER_EARLY_THROTTLE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Turns on early router throttling before allocating most of the router resources.
ROUTER_ENABLE_READ_THROTTLING - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_ENABLE_SSL - Static variable in class com.linkedin.venice.ConfigKeys
This instructs the router to open an ssl port.
ROUTER_FULL_PENDING_QUEUE_SERVER_OOR_MS - Static variable in class com.linkedin.venice.ConfigKeys
The following config controls how long the server with full pending queue will be taken OOR.
ROUTER_HEART_BEAT_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Disable router heart-beat job which marks hosts as unhealthy.
ROUTER_HELIX_ASSISTED_ROUTING_GROUP_SELECTION_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
Helix group selection strategy when Helix assisted routing is enabled.
ROUTER_HELIX_VIRTUAL_GROUP_FIELD_IN_DOMAIN - Static variable in class com.linkedin.venice.ConfigKeys
The Helix virtual group field name in domain, and the allowed values: HelixInstanceConfigRepository.GROUP_FIELD_NAME_IN_DOMAIN and HelixInstanceConfigRepository.ZONE_FIELD_NAME_IN_DOMAIN.
ROUTER_HTTP_CLIENT_OPENSSL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable openssl in the Router http client when talking to server.
ROUTER_HTTP_CLIENT_POOL_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
The http client pool size being used in one Router;
ROUTER_HTTP_CLIENT5_POOL_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
HttpClient5 pool size.
ROUTER_HTTP_CLIENT5_SKIP_CIPHER_CHECK_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to skip the cipher check when using Httpclient5.
ROUTER_HTTP_CLIENT5_TOTAL_IO_THREAD_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
Total IO thread count for HttpClient5 pool.
ROUTER_HTTP2_HEADER_TABLE_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Allows the sender to inform the remote endpoint of the maximum size of the header compression table used to decode header blocks, in octets.
ROUTER_HTTP2_INBOUND_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to support http/2 inbound request.
ROUTER_HTTP2_INITIAL_WINDOW_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Indicates the sender's initial window size (in octets) for stream-level flow control.
ROUTER_HTTP2_MAX_CONCURRENT_STREAMS - Static variable in class com.linkedin.venice.ConfigKeys
Indicates the maximum number of concurrent streams that the sender will allow.
ROUTER_HTTP2_MAX_FRAME_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Indicates the size of the largest frame payload that the sender is willing to receive, in octets.
ROUTER_HTTP2_MAX_HEADER_LIST_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
This advisory setting informs a peer of the maximum size of header list that the sender is prepared to accept, in octets.
ROUTER_HTTPASYNCCLIENT_CLIENT_POOL_THREAD_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
Number of IO threads used for AHAC client.
ROUTER_HTTPASYNCCLIENT_CONNECTION_WARMING_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Connection warming feature for httpasynclient.
ROUTER_HTTPASYNCCLIENT_CONNECTION_WARMING_EXECUTOR_THREAD_NUM - Static variable in class com.linkedin.venice.ConfigKeys
Connection warming executor thread num.
ROUTER_HTTPASYNCCLIENT_CONNECTION_WARMING_LOW_WATER_MARK - Static variable in class com.linkedin.venice.ConfigKeys
When the available connections in an httpasyncclient is below the low water mark, the connection warming service will try to spin up a new client to replace it.
ROUTER_HTTPASYNCCLIENT_CONNECTION_WARMING_NEW_INSTANCE_DELAY_JOIN_MS - Static variable in class com.linkedin.venice.ConfigKeys
For the new instance (Storage Node) detected by Router, the following config defines how much delay because of connection warming it could tolerate.
ROUTER_HTTPASYNCCLIENT_CONNECTION_WARMING_SLEEP_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
When Router starts, for a given route, the following config controls the warming up speed to minimize the impact to storage nodes.
ROUTER_HTTPAYSNCCLIENT_CONNECTION_WARMING_SOCKET_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to control the socket timeout for connection warming requests.
ROUTER_IDLE_CONNECTION_TO_SERVER_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable the cleanup of the idle connections to storage node.
ROUTER_IDLE_CONNECTION_TO_SERVER_CLEANUP_THRESHOLD_MINS - Static variable in class com.linkedin.venice.ConfigKeys
The idle threshold for cleaning up the connections to storage node.
ROUTER_IO_WORKER_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the Netty IO thread count for the Router Server
ROUTER_LEAKED_FUTURE_CLEANUP_POLL_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is for LeakedCompletableFutureCleanupService.
ROUTER_LEAKED_FUTURE_CLEANUP_THRESHOLD_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is for LeakedCompletableFutureCleanupService.
ROUTER_LONG_TAIL_RETRY_FOR_BATCH_GET_THRESHOLD_MS - Static variable in class com.linkedin.venice.ConfigKeys
After this amount of time, DDS Router will retry once for the slow storage node request.
ROUTER_LONG_TAIL_RETRY_FOR_SINGLE_GET_THRESHOLD_MS - Static variable in class com.linkedin.venice.ConfigKeys
After this amount of time, DDS Router will retry once for the slow storage node request.
ROUTER_LONG_TAIL_RETRY_MAX_ROUTE_FOR_MULTI_KEYS_REQ - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to limit the maximum retries in route unit.
ROUTER_MAX_CONCURRENT_RESOLUTIONS - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the maximum number of concurrent DNS resolutions that can be done by the router.
ROUTER_MAX_KEY_COUNT_IN_MULTIGET_REQ - Static variable in class com.linkedin.venice.ConfigKeys
The max key count allowed in one multi-get request.
ROUTER_MAX_OUTGOING_CONNECTION - Static variable in class com.linkedin.venice.ConfigKeys
The max connection number in one Router to storage nodes;
ROUTER_MAX_OUTGOING_CONNECTION_PER_ROUTE - Static variable in class com.linkedin.venice.ConfigKeys
The max connection number per route (to one storage node);
ROUTER_MAX_PENDING_REQUEST - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to bound the pending request.
ROUTER_MAX_READ_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_META_STORE_SHADOW_READ_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
The number of records
ROUTER_MULTI_KEY_ROUTING_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to define the routing strategy for multi-key requests.
ROUTER_MULTIGET_TARDY_LATENCY_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_NETTY_GRACEFUL_SHUTDOWN_PERIOD_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Netty graceful shutdown period considering the following factors: 1.
ROUTER_PARSE_URI - com.linkedin.alpini.base.misc.MetricNames
 
ROUTER_PENDING_CONNECTION_RESUME_THRESHOLD_PER_ROUTE - Static variable in class com.linkedin.venice.ConfigKeys
This is the threshold for pending request queue depth per storage node after which router resumes sending requests once a storage node which was previously marked unhealthy due to high ROUTER_UNHEALTHY_PENDING_CONNECTION_THRESHOLD_PER_ROUTE
ROUTER_PER_NODE_CLIENT_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Enables HttpAsyncClient allocation per storage node.
ROUTER_PER_NODE_CLIENT_THREAD_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_PER_STORE_ROUTER_QUOTA_BUFFER - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_PRINCIPAL_NAME - Static variable in class com.linkedin.venice.ConfigKeys
Venice router's principal name used for ssl.
ROUTER_QUOTA_CHECK_WINDOW - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_READ_QUOTA_THROTTLING_LEASE_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
Lease timeout for leaving quota disabled for a router.
ROUTER_RESOLVE_BEFORE_SSL - Static variable in class com.linkedin.venice.ConfigKeys
Config to control if DNS resolution should be done before SSL handshake between clients and a router.
ROUTER_RESPONSE_WAIT_TIME - com.linkedin.alpini.base.misc.MetricNames
 
ROUTER_ROUTING_TIME - com.linkedin.alpini.base.misc.MetricNames
 
ROUTER_SERVER_TIME - com.linkedin.alpini.base.misc.MetricNames
 
ROUTER_SINGLEGET_TARDY_LATENCY_MS - Static variable in class com.linkedin.venice.ConfigKeys
If a request is slower than this, it will be reported as tardy in the router metrics
ROUTER_SMART_LONG_TAIL_RETRY_ABORT_THRESHOLD_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to tune the smart long-tail retry logic to avoid unnecessary retries, check more details: ConfigKeys.ROUTER_SMART_LONG_TAIL_RETRY_ENABLED
ROUTER_SMART_LONG_TAIL_RETRY_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable smart long tail retry logic, and this logic is only useful for batch-get retry currently.
ROUTER_SOCKET_TIMEOUT - Static variable in class com.linkedin.venice.ConfigKeys
Socket timeout config for the connection manager from router to server
ROUTER_STATEFUL_HEALTHCHECK_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
ROUTER_STORAGE_NODE_CLIENT_TYPE - Static variable in class com.linkedin.venice.ConfigKeys
Whether the router use netty http client or apache http async client
ROUTER_UNHEALTHY_PENDING_CONNECTION_THRESHOLD_PER_ROUTE - Static variable in class com.linkedin.venice.ConfigKeys
Maximum number of pending router request per storage node after which router concludes that host to be unhealthy and stops sending further request to it..
ROUTER_USE_LOCAL_SSL_SETTINGS - Static variable in class com.linkedin.venice.ConfigKeys
This instructs the router to start running with self signed TLS certificates as opposed to those provided via other properties.
Router.Builder - Interface in com.linkedin.alpini.router.impl
 
Router.PipelineFactory<CHANNEL_HANDLER> - Interface in com.linkedin.alpini.router.impl
 
Router4<C extends io.netty.channel.Channel> - Class in com.linkedin.alpini.router.impl.netty4
 
Router4(ScatterGatherHelper) - Constructor for class com.linkedin.alpini.router.impl.netty4.Router4
 
Router4Impl<C extends io.netty.channel.Channel> - Class in com.linkedin.alpini.router.impl.netty4
 
Router4Impl(String, Class<? extends ServerSocketChannel>, EventLoopGroup, EventLoopGroup, EventExecutor, ConnectionLimitHandler, ActiveStreamsCountHandler, Http2SettingsFrameLogger, RouterTimeoutProcessor, Timer, Map<String, Object>, ScatterGatherHelper<H, P, K, R, BasicFullHttpRequest, FullHttpResponse, HttpResponseStatus>) - Constructor for class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
Router4PipelineFactory<C extends io.netty.channel.Channel> - Class in com.linkedin.alpini.router.impl.netty4
 
Router4PipelineFactory(ConnectionLimitHandler, ActiveStreamsCountHandler, Http2SettingsFrameLogger, Timer, BooleanSupplier, BooleanSupplier, ScatterGatherRequestHandler4<H, P, K, R>) - Constructor for class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
RouterBackedSchemaReader - Class in com.linkedin.venice.client.schema
 
RouterBackedSchemaReader(InternalAvroStoreClient, Optional<Schema>, Optional<Predicate<Schema>>, Duration, ICProvider) - Constructor for class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
RouterBackedSchemaReader(Supplier<InternalAvroStoreClient>, Optional<Schema>, Optional<Predicate<Schema>>) - Constructor for class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
RouterBackedSchemaReader(Supplier<InternalAvroStoreClient>, Optional<Schema>, Optional<Predicate<Schema>>, ICProvider) - Constructor for class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
RouterBackedSchemaReader(Supplier<InternalAvroStoreClient>, Optional<Schema>, Optional<Predicate<Schema>>, Duration) - Constructor for class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
RouterBackedSchemaReader(Supplier<InternalAvroStoreClient>, Optional<Schema>, Optional<Predicate<Schema>>, Duration, ICProvider) - Constructor for class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
RouterBasedHybridStoreQuotaMonitor - Class in com.linkedin.venice.pushmonitor
This push monitor is able to query hybrid store quota status from routers
RouterBasedHybridStoreQuotaMonitor(TransportClient, String, Version.PushType, String, RouterBasedHybridStoreQuotaMonitor.TransportClientReinitProvider) - Constructor for class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
 
RouterBasedHybridStoreQuotaMonitor.HybridQuotaMonitorTask - Class in com.linkedin.venice.pushmonitor
 
RouterBasedHybridStoreQuotaMonitor.TransportClientReinitProvider - Interface in com.linkedin.venice.pushmonitor
 
RouterBasedPushMonitor - Class in com.linkedin.venice.pushmonitor
This push monitor is able to query push job status from routers; it only works for stores running in Leader/Follower mode and it will be built for STREAM_REPROCESSING job.
RouterBasedPushMonitor(TransportClient, String, VeniceSystemFactory, SystemProducer) - Constructor for class com.linkedin.venice.pushmonitor.RouterBasedPushMonitor
 
RouterBasedStoreSchemaFetcher - Class in com.linkedin.venice.client.schema
Router based implementation of StoreSchemaFetcher.
RouterBasedStoreSchemaFetcher(AbstractAvroStoreClient) - Constructor for class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
RouterClusterConfigJSONSerializer - Class in com.linkedin.venice.helix
Serializer used to convert data between RouterClusterConfig Object and JSON string
RouterClusterConfigJSONSerializer() - Constructor for class com.linkedin.venice.helix.RouterClusterConfigJSONSerializer
 
RouterCurrentVersionStats - Class in com.linkedin.venice.router.stats
 
RouterCurrentVersionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.router.stats.RouterCurrentVersionStats
 
RouterException - Exception in com.linkedin.alpini.router.api
Exception class for checked exceptions within the Espresso Router.
RouterException(Class<STATUS>, STATUS, int, String, boolean) - Constructor for exception com.linkedin.alpini.router.api.RouterException
 
RouterException(Class<STATUS>, STATUS, int, String, boolean, Throwable) - Constructor for exception com.linkedin.alpini.router.api.RouterException
 
RouterException(Class<STATUS>, STATUS, int, String, boolean, Throwable, boolean, boolean) - Constructor for exception com.linkedin.alpini.router.api.RouterException
 
RouterExceptionAndTrackingUtils - Class in com.linkedin.venice.router.api
Right now, there is no simple way to capture all the exception cases with DDS Router.
RouterExceptionAndTrackingUtils() - Constructor for class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
 
RouterExceptionAndTrackingUtils.FailureType - Enum in com.linkedin.venice.router.api
 
RouterHeartbeat - Class in com.linkedin.venice.router.api
RouterHeartbeat is a service that monitors and reports the health of current live instances in the Venice cluster.
RouterHeartbeat(LiveInstanceMonitor, VeniceHostHealth, VeniceRouterConfig, Optional<SSLFactory>, StorageNodeClient) - Constructor for class com.linkedin.venice.router.api.RouterHeartbeat
 
RouterHttpRequestStats - Class in com.linkedin.venice.router.stats
 
RouterHttpRequestStats(MetricsRepository, String, RequestType, ScatterGatherStats, boolean) - Constructor for class com.linkedin.venice.router.stats.RouterHttpRequestStats
 
RouterKey - Class in com.linkedin.venice.router.api
RouterKey encapsulates the required information for a key in a router request.
RouterKey(byte[]) - Constructor for class com.linkedin.venice.router.api.RouterKey
 
RouterKey(ByteBuffer) - Constructor for class com.linkedin.venice.router.api.RouterKey
 
routerKeyMap - Variable in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
RouterPipelineFactory<CHANNEL_HANDLER> - Interface in com.linkedin.alpini.router.impl
 
RouterRequest - Class in com.linkedin.venice.listener.request
RouterRequest is an abstract base class for single-get and multi-get operations.
RouterRequest(String, boolean, boolean) - Constructor for class com.linkedin.venice.listener.request.RouterRequest
 
RouterRequest(String, HttpRequest) - Constructor for class com.linkedin.venice.listener.request.RouterRequest
 
RouterRequestHttpHandler - Class in com.linkedin.venice.listener
Monitors the stream, when it gets enough bytes that form a genuine object, it deserializes the object and passes it along the stack.
RouterRequestHttpHandler(StatsHandler, Map<String, Integer>) - Constructor for class com.linkedin.venice.listener.RouterRequestHttpHandler
 
RouterResourceType - Enum in com.linkedin.venice.router.api
 
RoutersClusterConfig - Class in com.linkedin.venice.meta
Cluster level metadata for all routers.
RoutersClusterConfig() - Constructor for class com.linkedin.venice.meta.RoutersClusterConfig
 
RoutersClusterConfigResponse - Class in com.linkedin.venice.controllerapi
 
RoutersClusterConfigResponse() - Constructor for class com.linkedin.venice.controllerapi.RoutersClusterConfigResponse
 
RoutersClusterConfigRoutes - Class in com.linkedin.venice.controller.server
 
RoutersClusterConfigRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
 
RoutersClusterManager - Interface in com.linkedin.venice.meta
This interface define the operations used to manage all routers in a cluster.
RoutersClusterManager.RouterCountChangedListener - Interface in com.linkedin.venice.meta
 
RouterServer - Class in com.linkedin.venice.router
 
RouterServer(VeniceProperties, HelixCustomizedViewOfflinePushRepository, Optional<HelixHybridStoreQuotaRepository>, HelixReadOnlyStoreRepository, HelixReadOnlySchemaRepository, HelixReadOnlyStoreConfigRepository, List<ServiceDiscoveryAnnouncer>, Optional<SSLFactory>, HelixLiveInstanceMonitor) - Constructor for class com.linkedin.venice.router.RouterServer
Only use this constructor for testing when you want to pass mock repositories Having separate constructors just for tests is hard to maintain, especially since in this case, the test constructor does not initialize manager...
RouterServer(VeniceProperties, List<ServiceDiscoveryAnnouncer>, Optional<DynamicAccessController>, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.router.RouterServer
 
RouterServer(VeniceProperties, List<ServiceDiscoveryAnnouncer>, Optional<DynamicAccessController>, Optional<SSLFactory>, MetricsRepository) - Constructor for class com.linkedin.venice.router.RouterServer
 
RouterSslVerificationHandler - Class in com.linkedin.venice.router
 
RouterSslVerificationHandler(SecurityStats) - Constructor for class com.linkedin.venice.router.RouterSslVerificationHandler
 
RouterSslVerificationHandler(SecurityStats, boolean) - Constructor for class com.linkedin.venice.router.RouterSslVerificationHandler
 
RouterStats<STAT_TYPE> - Class in com.linkedin.venice.router.stats
 
RouterStats(Function<RequestType, STAT_TYPE>) - Constructor for class com.linkedin.venice.router.stats.RouterStats
 
RouterThrottleHandler - Class in com.linkedin.venice.router
 
RouterThrottleHandler(RouterThrottleStats, EventThrottler, VeniceRouterConfig) - Constructor for class com.linkedin.venice.router.RouterThrottleHandler
 
RouterThrottler - Interface in com.linkedin.venice.router.throttle
 
RouterThrottleStats - Class in com.linkedin.venice.router.stats
 
RouterThrottleStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.router.stats.RouterThrottleStats
 
RouterTimeoutProcessor - Interface in com.linkedin.alpini.router.api
 
RouterTimeoutProcessor.TimeoutFuture - Interface in com.linkedin.alpini.router.api
 
routerUrl - Variable in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
RoutingDataRepository - Interface in com.linkedin.venice.meta
Repository to access routing data like Partition and replica.
RoutingDataRepository.RoutingDataChangedListener - Interface in com.linkedin.venice.meta
 
routingInfo - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Routing table information, maps resource to partition ID to a list of replicas
routingStrategy - Variable in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
routingStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
routingStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
How to route the key to partition, and default is 'CONSISTENT_HASH'
RoutingStrategy - Enum in com.linkedin.venice.meta
Enums of strategies used to route the key to partition in Venice.
RT_WRITE_ONLY - com.linkedin.venice.hadoop.input.kafka.ttl.TTLResolutionPolicy
Only real-time(RT) data, which can contain the RMD, will be TTLed.
run() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
Run the Callable.
run() - Method in class com.linkedin.alpini.base.concurrency.RunOnce
 
run() - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
run() - Method in class com.linkedin.davinci.kafka.consumer.ParticipantStoreConsumptionTask
 
run() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Polls the producer for new messages in an infinite loop by a dedicated consumer thread and processes the new messages by current thread.
run() - Method in class com.linkedin.venice.controller.authorization.SystemStoreAclSynchronizationTask
Since acl synchronization could be a long-running task we want to make sure we can handle stale states from local variable, race conditions and early termination gracefully.
run() - Method in class com.linkedin.venice.controller.ErrorPartitionResetTask
 
run() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumptionTask
 
run() - Method in class com.linkedin.venice.controller.systemstore.SystemStoreRepairTask
 
run() - Method in class com.linkedin.venice.controller.TerminalStateTopicCheckerForParentController
 
run() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
 
run() - Method in class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSender
 
run() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
run() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor.HybridQuotaMonitorTask
 
run() - Method in interface com.linkedin.venice.utils.VeniceCheckedRunnable
 
run(VeniceConfigLoader, boolean) - Static method in class com.linkedin.venice.server.VeniceServer
 
run(String, boolean) - Static method in class com.linkedin.venice.router.RouterServer
 
run(String, boolean) - Static method in class com.linkedin.venice.server.VeniceServer
 
run(String, String, boolean) - Static method in class com.linkedin.venice.controller.VeniceController
 
run(Consumer<Double>) - Static method in interface com.linkedin.venice.utils.Timer
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
runAfterBoth(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
runAfterEither(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
runAndReset() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
 
RunBnPAndVPJWaitForBnPOnlyStrategy - com.linkedin.venice.migration.MigrationPushStrategy
 
RunBnPAndVPJWaitForBothStrategy - com.linkedin.venice.migration.MigrationPushStrategy
 
RunBnPAndVPJWaitForVPJOnlyStrategy - com.linkedin.venice.migration.MigrationPushStrategy
 
RunBnPOnlyStrategy - com.linkedin.venice.migration.MigrationPushStrategy
 
runComputeJob() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
runComputeJob() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
runComputeJob() - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
runJob() - Method in interface com.linkedin.venice.hadoop.jobs.ComputeJob
 
runJob() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
runJobWithConfig(JobConf) - Method in interface com.linkedin.venice.hadoop.JobClientWrapper
 
runJobWithConfig(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.engine.DefaultJobClientWrapper
 
runJobWithConfig(JobConf, JobClientWrapper) - Static method in class com.linkedin.venice.hadoop.mapreduce.common.JobUtils
 
RunnableScheduledFuture<V> - Interface in com.linkedin.alpini.base.misc
 
RUNNING - com.linkedin.alpini.netty4.handlers.VIPRequestHandler.State
The router is up and running.
RUNNING - com.linkedin.venice.hadoop.jobs.ComputeJob.Status
A job that is currently executing
RUNNING - com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
 
RunOnce - Class in com.linkedin.alpini.base.concurrency
A simple filter Runnable which will only invoke the contained runnable no more than once.
RunOnce(Runnable) - Constructor for class com.linkedin.alpini.base.concurrency.RunOnce
 
runPushJob(String, Properties) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
runPushJob(String, Properties, Consumer<VenicePushJob>) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
RunVPJOnlyStrategy - com.linkedin.venice.migration.MigrationPushStrategy
 

S

SafeAllocator - Class in com.linkedin.alpini.base.safealloc
An instance of SafeAllocator may be used to wrap an existing ByteBufAllocator to provide insurance against slow memory leaks from exceptional conditions by providing a means for the leaked ByteBuf objects to be reclaimed.
SafeAllocator(ByteBufAllocator) - Constructor for class com.linkedin.alpini.base.safealloc.SafeAllocator
 
SafeAllocatorMetric - Class in com.linkedin.alpini.base.safealloc
Metrics regarding the SafeAllocator
SafeHelixDataAccessor - Class in com.linkedin.venice.helix
A wrapper around HelixDataAccessor which disables the unsafe functionality.
SafeHelixDataAccessor(HelixDataAccessor) - Constructor for class com.linkedin.venice.helix.SafeHelixDataAccessor
 
SafeHelixManager - Class in com.linkedin.venice.helix
A wrapper around HelixManager which disables the unsafe functionality.
SafeHelixManager(HelixManager) - Constructor for class com.linkedin.venice.helix.SafeHelixManager
 
Sample(T) - Constructor for class com.linkedin.alpini.base.statistics.GenericQuantileEstimation.Sample
 
SamzaExitMode - Enum in com.linkedin.venice.samza
Various methods for stopping/exiting a Samza task.
sanitizeHeadersBeforeEncode(H, boolean) - Method in class io.netty.handler.codec.http.EspressoHttpObjectEncoder
Allows to sanitize headers of the message before encoding these.
sanitizeHeaderValue(CharSequence) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Builds a new String, filtering out values and performing fixup to provide a value which may be set as a HTTP header value.
sanitizeStatusMessage(CharSequence) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Builds a new String, filtering out non-ASCII characters which are likely to cause problems.
saveForkedIngestionKafkaClusterMapConfig(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
saveForkedIngestionProcessMetadata(VeniceConfigLoader, ForkedJavaProcess) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
saveSchemasOnDisk(ControllerClient) - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
This method loads related configs, gets store value and RMD schemas from Venice controllers, and then write them on HDFS.
SC_MISDIRECTED_REQUEST - Static variable in class com.linkedin.venice.HttpConstants
 
scatter(Scatter<H, P, K>, String, String, AsyncPartitionFinder<K>, HostFinder<H, R>, HostHealthMonitor<H>, R) - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
 
scatter(Scatter<H, P, K>, String, String, PartitionFinder<K>, HostFinder<H, R>, HostHealthMonitor<H>, R) - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
Deprecated.
scatter(Scatter<H, P, K>, String, String, PartitionFinder<K>, HostFinder<H, R>, HostHealthMonitor<H>, R) - Method in class com.linkedin.venice.router.api.VeniceDelegateMode
 
scatter(String, P, Headers, HostHealthMonitor<H>, Metrics, String) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
Scatter<H,​P extends ResourcePath<K>,​K> - Class in com.linkedin.alpini.router.api
Collection of ScatterGatherRequests for a request to the router.
Scatter(P, ResourcePathParser<P, K>, Object) - Constructor for class com.linkedin.alpini.router.api.Scatter
 
ScatterGatherHelper<H,​P extends ResourcePath<K>,​K,​R,​BASIC_HTTP_REQUEST extends BasicRequest,​HTTP_RESPONSE,​HTTP_RESPONSE_STATUS> - Class in com.linkedin.alpini.router.api
 
ScatterGatherHelper(ExtendedResourcePathParser<P, K, BASIC_HTTP_REQUEST>, AsyncPartitionFinder<K>, HostFinder<H, R>, HostHealthMonitor<H>, RoleFinder<R>, ScatterGatherMode, ScatterGatherMode, PartitionDispatchHandler<H, P, K, BASIC_HTTP_REQUEST, HTTP_RESPONSE, HTTP_RESPONSE_STATUS>, Optional<ResponseAggregatorFactory<BASIC_HTTP_REQUEST, HTTP_RESPONSE>>, Function<Headers, Long>, LongTailRetrySupplier<P, K>, Function<BasicRequest, Metrics>, BiFunction<Headers, Metrics, Headers>, Function<Headers, Metrics>, Function<P, ScatterGatherStats>, long, long, long, List<Pair<String, Supplier<?>>>, List<Pair<String, Supplier<?>>>, List<Pair<String, Supplier<?>>>, List<Pair<String, Supplier<?>>>, IntPredicate, RequestRetriableChecker<P, R, HTTP_RESPONSE_STATUS>, boolean, BooleanSupplier, BooleanSupplier, BooleanSupplier) - Constructor for class com.linkedin.alpini.router.api.ScatterGatherHelper
 
ScatterGatherHelper.Builder<H,​P extends ResourcePath<K>,​K,​R,​HTTP_REQUEST extends BasicRequest,​HTTP_RESPONSE,​HTTP_RESPONSE_STATUS> - Class in com.linkedin.alpini.router.api
 
ScatterGatherMode - Class in com.linkedin.alpini.router.api
Created by acurtis on 6/20/17.
ScatterGatherMode(String, boolean) - Constructor for class com.linkedin.alpini.router.api.ScatterGatherMode
 
ScatterGatherRequest<H,​K> - Class in com.linkedin.alpini.router.api
Routing information for part of a request which the router has mapped to a single storage node.
ScatterGatherRequest(List<H>, Set<K>) - Constructor for class com.linkedin.alpini.router.api.ScatterGatherRequest
 
ScatterGatherRequestHandler<H,​P extends ResourcePath<K>,​K,​R> - Class in com.linkedin.alpini.router
 
ScatterGatherRequestHandler(TimeoutProcessor) - Constructor for class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
ScatterGatherRequestHandler(RouterTimeoutProcessor) - Constructor for class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
ScatterGatherRequestHandler4<H,​P extends ResourcePath<K>,​K,​R> - Class in com.linkedin.alpini.router
 
ScatterGatherRequestHandler4(ScatterGatherHelper<H, P, K, R, BasicFullHttpRequest, FullHttpResponse, HttpResponseStatus>, TimeoutProcessor, Executor) - Constructor for class com.linkedin.alpini.router.ScatterGatherRequestHandler4
Deprecated.
ScatterGatherRequestHandler4(ScatterGatherHelper<H, P, K, R, BasicFullHttpRequest, FullHttpResponse, HttpResponseStatus>, RouterTimeoutProcessor, Executor) - Constructor for class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
ScatterGatherRequestHandlerImpl<H,​P extends ResourcePath<K>,​K,​R,​CHC,​BHS extends BasicRequest,​HR,​HRS extends io.netty.handler.codec.http.HttpResponseStatus,​SCATTER_GATHER_HELPER extends ScatterGatherHelper<H,​P,​K,​R,​BHS,​HR,​HRS>> - Class in com.linkedin.alpini.router
 
ScatterGatherRequestHandlerImpl(SCATTER_GATHER_HELPER, TimeoutProcessor) - Constructor for class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
ScatterGatherRequestHandlerImpl(SCATTER_GATHER_HELPER, RouterTimeoutProcessor) - Constructor for class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
ScatterGatherStats - Class in com.linkedin.alpini.router.monitoring
 
ScatterGatherStats() - Constructor for class com.linkedin.alpini.router.monitoring.ScatterGatherStats
 
ScatterGatherStats.Delta - Class in com.linkedin.alpini.router.monitoring
 
ScatterGatherStatsMBean - Interface in com.linkedin.alpini.router.monitoring
 
scatterGatherStatsProvider(Function<P, ScatterGatherStats>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
scatterMode(ScatterGatherMode) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
schedule(Runnable, long, TimeUnit) - Method in interface com.linkedin.alpini.base.concurrency.ScheduledExecutorService
Creates and executes a one-shot action that becomes enabled after the given delay.
schedule(Runnable, long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor
Schedule a timeout event to occur after the specified delay
schedule(Runnable, long, TimeUnit) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
 
schedule(Runnable, long, TimeUnit) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableScheduledExecutorServiceImpl
 
schedule(Runnable, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
schedule(Runnable, long, TimeUnit) - Method in interface com.linkedin.alpini.router.api.RouterTimeoutProcessor
 
schedule(Runnable, long, TimeUnit) - Method in class com.linkedin.alpini.router.impl.netty4.TimerTimeoutProcessor
 
schedule(Callable<V>, long, TimeUnit) - Method in interface com.linkedin.alpini.base.concurrency.ScheduledExecutorService
Creates and executes a ScheduledFuture that becomes enabled after the given delay.
schedule(Callable<V>, long, TimeUnit) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableScheduledExecutorServiceImpl
 
schedule(Callable<V>, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface com.linkedin.alpini.base.concurrency.ScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given period; that is executions will commence after initialDelay then initialDelay+period, then initialDelay + 2 * period, and so on.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableScheduledExecutorServiceImpl
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
ScheduledExecutorService - Interface in com.linkedin.alpini.base.concurrency
An analog to ScheduledExecutorService which extends ExecutorService.
ScheduledFuture<V> - Interface in com.linkedin.alpini.base.misc
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface com.linkedin.alpini.base.concurrency.ScheduledExecutorService
Creates and executes a periodic action that becomes enabled first after the given initial delay, and subsequently with the given delay between the termination of one execution and the commencement of the next.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableScheduledExecutorServiceImpl
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
schema - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
schema - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
schema() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputTable
 
Schema() - Constructor for class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
SCHEMA_COMPAT_TYPE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
SCHEMA_HEADER_LENGTH - Static variable in class com.linkedin.davinci.store.record.ValueRecord
 
SCHEMA_HEADER_LENGTH - Static variable in class com.linkedin.venice.compression.VeniceCompressor
 
SCHEMA_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
SCHEMA_NOT_FOUND - com.linkedin.venice.exceptions.ErrorType
 
SCHEMA_NOT_FOUND - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
SCHEMA_POLLING_DELAY_MS - Static variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
SCHEMA_STRING_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SCHEMA$ - Static variable in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
SCHEMA$ - Static variable in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
SCHEMA$ - Static variable in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
SCHEMA$ - Static variable in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
SCHEMA$ - Static variable in class com.linkedin.venice.client.store.schemas.TestKeyRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.client.store.schemas.TestValueRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
SCHEMA$ - Static variable in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.Count
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.DotProduct
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
SCHEMA$ - Static variable in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
SCHEMA$ - Static variable in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
SCHEMA$ - Static variable in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
SCHEMA$ - Static variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
SCHEMA$ - Static variable in enum com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
 
SCHEMA$ - Static variable in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
SCHEMA$ - Static variable in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
SCHEMA$ - Static variable in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
SCHEMA$ - Static variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
SCHEMA$ - Static variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
SCHEMA$ - Static variable in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
SCHEMA$ - Static variable in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.ControlMessage
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.Delete
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.EndOfPush
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.GUID
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.Put
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.StartOfPush
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.Update
 
SCHEMA$ - Static variable in class com.linkedin.venice.kafka.protocol.VersionSwap
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
SCHEMA$ - Static variable in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
SCHEMA$ - Static variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
SCHEMA$ - Static variable in class com.linkedin.venice.metadata.response.VersionProperties
 
SCHEMA$ - Static variable in class com.linkedin.venice.participant.protocol.KillPushJob
 
SCHEMA$ - Static variable in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
SCHEMA$ - Static variable in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
SCHEMA$ - Static variable in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
SCHEMA$ - Static variable in class com.linkedin.venice.pushstatus.PushStatusKey
 
SCHEMA$ - Static variable in class com.linkedin.venice.pushstatus.PushStatusValue
 
SCHEMA$ - Static variable in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
SCHEMA$ - Static variable in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
SCHEMA$ - Static variable in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
SCHEMA$ - Static variable in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
SCHEMA$ - Static variable in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
SCHEMA$ - Static variable in class com.linkedin.venice.status.protocol.PushJobDetails
 
SCHEMA$ - Static variable in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
SCHEMA$ - Static variable in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
SCHEMA$ - Static variable in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
SCHEMA$ - Static variable in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
SCHEMA$ - Static variable in class com.linkedin.venice.storage.protocol.ChunkId
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
SCHEMA$ - Static variable in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
SchemaAdapter - Interface in com.linkedin.venice.schema
Try to adapt the {@param datum} to the {@param expectedSchema}.
SchemaAndToString - Class in com.linkedin.venice.client.schema
Used to cache the toString of a given schema, since it is expensive to compute.
SchemaAndToString(Schema) - Constructor for class com.linkedin.venice.client.schema.SchemaAndToString
 
schemaAutoRegisteFromPushJobEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not value schema auto registration enabled from push job for this store.
schemaAutoRegisterFromPushJobEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
schemaAutoRegisterFromPushJobEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
SchemaCompatibility - Class in com.linkedin.venice.schema.avro
Evaluate the compatibility between a reader schema and a writer schema.
SchemaCompatibility.SchemaCompatibilityType - Enum in com.linkedin.venice.schema.avro
Identifies the type of a schema compatibility result.
SchemaCompatibility.SchemaPairCompatibility - Class in com.linkedin.venice.schema.avro
Provides information about the compatibility of a single reader and writer schema pair.
SchemaData - Class in com.linkedin.venice.schema
This class is used to store all the schemas related to a given store: 1.
SchemaData(String, SchemaEntry) - Constructor for class com.linkedin.venice.schema.SchemaData
 
SchemaDuplicateException - Exception in com.linkedin.venice.exceptions
 
SchemaDuplicateException(SchemaEntry, SchemaEntry) - Constructor for exception com.linkedin.venice.exceptions.SchemaDuplicateException
 
SchemaEntry - Class in com.linkedin.venice.schema
SchemaEntry is composed of a schema and its corresponding id.
SchemaEntry(int, byte[]) - Constructor for class com.linkedin.venice.schema.SchemaEntry
 
SchemaEntry(int, String) - Constructor for class com.linkedin.venice.schema.SchemaEntry
Primary constructor taking a literal id and schema.
SchemaEntry(int, Schema) - Constructor for class com.linkedin.venice.schema.SchemaEntry
 
SchemaEntrySerializer - Class in com.linkedin.venice.helix
This class to use to serialize/deserialize Zookeeper node
SchemaEntrySerializer() - Constructor for class com.linkedin.venice.helix.SchemaEntrySerializer
 
schemaId - Variable in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
schemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
schemaId - Variable in class com.linkedin.venice.DumpAdminMessages.AdminOperationInfo
 
schemaId - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
The schema id of the original record
schemaId - Variable in class com.linkedin.venice.kafka.protocol.Delete
An identifier used, in conjunction with the replicationMetadataVersionId, to deserialize the replicationMetadataPayload.
schemaId - Variable in class com.linkedin.venice.kafka.protocol.Put
An identifier used to determine how the PutValue can be deserialized.
schemaId - Variable in class com.linkedin.venice.kafka.protocol.Update
The original schema ID.
schemaId - Variable in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Schema id of current store being used when serializing this record
schemaId - Variable in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
An identifier used to determine how the full value (after chunk re-assembly) can be deserialized.
SCHEMAID_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
 
schemaIds - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
SchemaIncompatibilityException - Exception in com.linkedin.venice.exceptions
Throw this exception when the schema is not fully compatible with the previous ones.
SchemaIncompatibilityException(SchemaEntry, SchemaEntry) - Constructor for exception com.linkedin.venice.exceptions.SchemaIncompatibilityException
 
SchemaMeta - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
SchemaMeta() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
Default constructor.
SchemaMeta(Integer, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
All-args constructor.
schemaNameEquals(Schema, Schema) - Static method in class com.linkedin.venice.schema.avro.SchemaCompatibility
Tests the equality of two Avro named schemas.
SchemaPairAndClassContainer(Schema, Schema, Class) - Constructor for class com.linkedin.venice.serializer.SerializerDeserializerFactory.SchemaPairAndClassContainer
 
SchemaPairCompatibility(SchemaCompatibility.SchemaCompatibilityType, Schema, Schema, String) - Constructor for class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
Constructs a new instance.
SchemaPresenceChecker - Class in com.linkedin.venice.serialization.avro
This class helps checks presence of a schema version in ZK.
SchemaPresenceChecker(SchemaReader, AvroProtocolDefinition) - Constructor for class com.linkedin.venice.serialization.avro.SchemaPresenceChecker
 
schemaReader - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
SchemaReader - Interface in com.linkedin.venice.schema
This interface is considered as an internal interface to Venice codebase.
SchemaRepoBackedSchemaReader - Class in com.linkedin.venice.schema
 
SchemaRepoBackedSchemaReader(ReadOnlySchemaRepository, String) - Constructor for class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
 
schemaRepository - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
schemaResolveHasErrors(Schema, Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
Preemptive check to see if the given writer and reader schema can be resolved without errors.
SchemaResponse - Class in com.linkedin.venice.controllerapi
 
SchemaResponse() - Constructor for class com.linkedin.venice.controllerapi.SchemaResponse
 
SchemaRoutes - Class in com.linkedin.venice.controller.server
 
SchemaRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.SchemaRoutes
 
SchemaSource - Interface in com.linkedin.venice.hadoop.schema
A high-level interface as a source specifically for RmdSchema.
schemaType - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
0 => Avro-1.4, and we can add more if necessary
SchemaType - Enum in com.linkedin.venice.controller.kafka.protocol.enums
 
SchemaUsageResponse - Class in com.linkedin.venice.controllerapi
 
SchemaUsageResponse() - Constructor for class com.linkedin.venice.controllerapi.SchemaUsageResponse
 
SchemaUtils - Class in com.linkedin.davinci.schema
 
searchForFileExtension(File, String) - Static method in class com.linkedin.venice.utils.TestUtils
 
SECONDS_PER_DAY - Static variable in interface com.linkedin.venice.utils.Time
 
SECONDS_PER_HOUR - Static variable in interface com.linkedin.venice.utils.Time
 
SECONDS_PER_MINUTE - Static variable in interface com.linkedin.venice.utils.Time
 
SecureClientHandler - Class in com.linkedin.alpini.netty4.ssl
This is a port of the com.linkedin.security.netty.ssl.access.control.SecureClientHandler class as a netty 4 implementation.
SecureClientHandler() - Constructor for class com.linkedin.alpini.netty4.ssl.SecureClientHandler
 
SecureClientHandler(BiPredicate<ChannelHandlerContext, X509Certificate>) - Constructor for class com.linkedin.alpini.netty4.ssl.SecureClientHandler
 
SecurityStats - Class in com.linkedin.venice.router.stats
 
SecurityStats(MetricsRepository, String, IntSupplier) - Constructor for class com.linkedin.venice.router.stats.SecurityStats
 
seekToBeginningOfPush() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the beginning of the push for subscribed partitions.
seekToBeginningOfPush() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToBeginningOfPush(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the beginning of the push for a set of partitions.
seekToBeginningOfPush(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToCheckpoint(Set<VeniceChangeCoordinate>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek the provided checkpoints for the specified partitions.
seekToCheckpoint(Set<VeniceChangeCoordinate>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToEndOfPush() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the end of the push for all subscribed partitions.
seekToEndOfPush() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToEndOfPush(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
seekToEndOfPush(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the end of the last push for a given set of partitions.
seekToEndOfPush(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToTail() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the end of events which have been transmitted to Venice for all subscribed partitions.
seekToTail() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToTail(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
seekToTail(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the end of events which have been transmitted to Venice and start consuming new events.
seekToTail(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToTimestamp(Long) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the specified timestamp for all subscribed partitions.
seekToTimestamp(Long) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
seekToTimestamps(Map<Integer, Long>) - Method in class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
seekToTimestamps(Map<Integer, Long>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Seek to the provided timestamps for the specified partitions based on wall clock time for when this message was processed by Venice and produced to change capture.
seekToTimestamps(Map<Integer, Long>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
Segment - Class in com.linkedin.venice.kafka.validation
A segment is a sequence of messages sent by a single producer into a single partition.
Segment(int, int, int, CheckSumType, Map<CharSequence, CharSequence>, Map<CharSequence, Long>) - Constructor for class com.linkedin.venice.kafka.validation.Segment
 
Segment(int, int, CheckSumType) - Constructor for class com.linkedin.venice.kafka.validation.Segment
 
Segment(int, ProducerPartitionState) - Constructor for class com.linkedin.venice.kafka.validation.Segment
Build a segment with checkpoint producer state on disk.
Segment(Segment) - Constructor for class com.linkedin.venice.kafka.validation.Segment
 
segmentNumber - Variable in class com.linkedin.venice.kafka.protocol.ProducerMetadata
A number used to disambiguate between sequential segments sent into a given partition by a given producer.
segmentNumber - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The current segment number corresponds to the last (highest) segment number for which we have seen a StartOfSegment control message.
segmentNumber - Variable in class com.linkedin.venice.storage.protocol.ChunkId
The segment number of the first chunk sent as part of this multi-chunk value.
segmentStatus - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
The status of the current segment: 0 => NOT_STARTED, 1 => IN_PROGRESS, 2 => END_OF_INTERMEDIATE_SEGMENT, 3 => END_OF_FINAL_SEGMENT.
SegmentStatus - Enum in com.linkedin.venice.kafka.validation
 
selectGroup(long, int) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
 
selectGroup(long, int) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupRoundRobinStrategy
 
selectGroup(long, int) - Method in interface com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategy
Select a Helix Group for the current request.
selectGroup(long, int) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
 
self() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
send(Object, Object) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
send(String, OutgoingMessageEnvelope) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
SEND_CONTROL_MESSAGES_DIRECTLY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SEND_END_OF_PUSH - com.linkedin.venice.Command
 
SEND_HEARTBEAT_TIMESTAMP_TO_SYSTEM_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
SEND_PUSH_JOB_DETAILS - com.linkedin.venice.controllerapi.ControllerRoute
 
SEND_START_OF_PUSH - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
sendControlMessage(ControlMessage, int, Map<String, String>, PubSubProducerCallback, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
This function sends a control message into the prescribed partition.
sendControlMessagesDirectly - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
sendD2GetRequest(String, D2Client) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
sendEmptyPushAndWait(String, String, long, long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
Sends and empty push to the venice controller, but verifies that the push has succeeded before returning to the caller.
sendHeartbeat(PubSubTopicPartition, PubSubProducerCallback, LeaderMetadataWrapper, boolean, LeaderCompleteState, long) - Method in class com.linkedin.venice.writer.VeniceWriter
 
sendHeartbeatRequest() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
sendHeartbeatToSystemStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
sendHeartbeatToSystemStore(String, long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
sendHeartbeatToSystemStore(String, String, long) - Method in interface com.linkedin.venice.controller.Admin
Send a heartbeat timestamp to targeted system store.
sendHeartbeatToSystemStore(String, String, long) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
sendHeartbeatToSystemStore(String, String, long) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
sendLivenessHeartbeatFailureDetails - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
Failure details of sending liveness heartbeat from the push job.
sendMessage(String, Integer, KafkaKey, KafkaMessageEnvelope, PubSubMessageHeaders, PubSubProducerCallback) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
Sends a message to the Kafka Producer.
sendMessage(String, Integer, KafkaKey, KafkaMessageEnvelope, PubSubMessageHeaders, PubSubProducerCallback) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
Sends a message to a PubSub topic asynchronously and returns a Future representing the result of the produce operation.
sendMessage(String, Integer, KafkaKey, KafkaMessageEnvelope, PubSubMessageHeaders, PubSubProducerCallback) - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
 
sendMessage(String, Integer, KafkaKey, KafkaMessageEnvelope, PubSubMessageHeaders, PubSubProducerCallback) - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
 
SendMessageParameters(String, KafkaKey, KafkaMessageEnvelope, int) - Constructor for class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter.SendMessageParameters
 
sendPing() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
sendPing(Channel) - Method in class com.linkedin.alpini.netty4.pool.Http2PingHelper
 
sendPushJobDetails(Admin) - Method in class com.linkedin.venice.controller.server.JobRoutes
 
sendPushJobDetails(PushJobStatusRecordKey, PushJobDetails) - Method in interface com.linkedin.venice.controller.Admin
 
sendPushJobDetails(PushJobStatusRecordKey, PushJobDetails) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Lazy initialize a Venice writer for an internal real time topic store of push job details records.
sendPushJobDetails(PushJobStatusRecordKey, PushJobDetails) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
sendPushJobDetails(String, int, byte[]) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
sendPushJobDetails(String, int, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
sendRequest(IngestionAction, S) - Method in class com.linkedin.davinci.ingestion.HttpClientTransport
 
sendRequest(IngestionAction, S, int) - Method in class com.linkedin.davinci.ingestion.HttpClientTransport
This method shoves the POST string query params into the URL so the body will only contain the byte array data to make processing/deserializing easier.
sendRequest(Instance, VenicePath, AsyncPromise<HttpResponseStatus>) - Method in class com.linkedin.venice.router.api.VeniceDispatcher
 
sendRequest(VeniceMetaDataRequest, CompletableFuture<PortableHttpResponse>) - Method in class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
 
sendRequest(VeniceMetaDataRequest, CompletableFuture<PortableHttpResponse>) - Method in class com.linkedin.venice.router.httpclient.HttpClient5StorageNodeClient
 
sendRequest(VeniceMetaDataRequest, CompletableFuture<PortableHttpResponse>) - Method in interface com.linkedin.venice.router.httpclient.StorageNodeClient
 
sendRequestWithRetry(IngestionAction, S, int) - Method in class com.linkedin.davinci.ingestion.HttpClientTransport
 
sendStartOfSegment(int, Map<String, String>) - Method in class com.linkedin.venice.writer.VeniceWriter
Send a ControlMessageType.START_OF_SEGMENT control message into the designated partition.
sendToController(StatusMessage) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
sendToController(StatusMessage) - Method in interface com.linkedin.venice.status.StatusMessageChannel
Send message to controller.
sendToController(StatusMessage, int, long) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
sendToController(StatusMessage, int, long) - Method in interface com.linkedin.venice.status.StatusMessageChannel
Send message to controller.
sendToStorageNodes(String, StatusMessage, String, int) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
sendToStorageNodes(String, StatusMessage, String, int) - Method in interface com.linkedin.venice.status.StatusMessageChannel
Send message to all storage nodes in the given cluster.
SENTINEL_PROTOCOL_VERSION_USED_FOR_UNDETECTABLE_COMPILED_SCHEMA - Static variable in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
SENTINEL_PROTOCOL_VERSION_USED_FOR_UNVERSIONED_PROTOCOL - Static variable in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
SentPushJobDetailsTracker - Interface in com.linkedin.venice.hadoop
Interface of class that is used to keep track of push job details sent to the Venice controller.
SEP - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
SeparatedStoreBufferService - Class in com.linkedin.davinci.kafka.consumer
This store buffer services maintains two separate drainer queues for store ingestions.
SEPARATOR - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
 
SerializableSystemStore - Class in com.linkedin.venice.meta
 
SerializableSystemStore(ZKStore, VeniceSystemStoreType, ZKStore) - Constructor for class com.linkedin.venice.meta.SerializableSystemStore
 
serialize() - Method in class com.linkedin.davinci.store.record.ValueRecord
 
serialize() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
 
serialize(AdminOperation) - Method in class com.linkedin.venice.controller.kafka.protocol.serializer.AdminOperationSerializer
 
serialize(SerializableSystemStore, String) - Method in class com.linkedin.venice.helix.SystemStoreJSONSerializer
 
serialize(Store, String) - Method in class com.linkedin.venice.helix.StoreJSONSerializer
 
serialize(SchemaEntry, String) - Method in class com.linkedin.venice.helix.SchemaEntrySerializer
This function only serialize schema content, and the caller will be charge of storing schema id as part of file path.
serialize(Object, String) - Method in class com.linkedin.venice.helix.HelixAdapterSerializer
 
serialize(String, byte[]) - Method in class com.linkedin.venice.serialization.DefaultSerializer
 
serialize(String, KafkaKey) - Method in class com.linkedin.venice.serialization.KafkaKeySerializer
 
serialize(String, Object) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
 
serialize(String, String) - Method in class com.linkedin.venice.meta.SimpleStringSerializer
 
serialize(String, String) - Method in class com.linkedin.venice.serialization.StringSerializer
 
serialize(String, SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
Construct an array of bytes from the given object
serialize(String, T) - Method in interface com.linkedin.venice.serialization.VeniceKafkaSerializer
Construct an array of bytes from the given object
serialize(K) - Method in class com.linkedin.venice.serializer.AvroSerializer
 
serialize(SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
serialize(T) - Method in interface com.linkedin.venice.serializer.RecordSerializer
 
serialize(T, String) - Method in class com.linkedin.venice.helix.AbstractSchemaEntrySerializer
 
serialize(T, String) - Method in class com.linkedin.venice.helix.VeniceJsonSerializer
 
serialize(T, String) - Method in interface com.linkedin.venice.meta.VeniceSerializer
 
serializeChunkedKey(byte[], ChunkedKeySuffix) - Method in class com.linkedin.venice.serialization.KeyWithChunkingSuffixSerializer
 
serializedResponse() - Method in class com.linkedin.davinci.listener.response.AdminResponse
 
serializeIngestionActionRequest(IngestionAction, T) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
serializeIngestionActionResponse(IngestionAction, T) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
serializeKey(String, String) - Static method in class com.linkedin.venice.TopicMessageFinder
 
serializeNonChunkedKey(byte[]) - Method in class com.linkedin.venice.serialization.KeyWithChunkingSuffixSerializer
 
serializeNonChunkedKey(ByteBuffer) - Method in class com.linkedin.venice.serialization.KeyWithChunkingSuffixSerializer
 
serializeNonChunkedKeyAsByteBuffer(byte[]) - Method in class com.linkedin.venice.serialization.KeyWithChunkingSuffixSerializer
 
serializeObjects(Iterable<K>) - Method in class com.linkedin.venice.serializer.AvroSerializer
 
serializeObjects(Iterable<K>, ByteBuffer) - Method in class com.linkedin.venice.serializer.AvroSerializer
Serialize a list of objects and put the prefix before the serialized objects.
serializeObjects(Iterable<K>, BinaryEncoder, ByteArrayOutputStream) - Method in class com.linkedin.venice.serializer.AvroSerializer
 
serializeObjects(Iterable<T>) - Method in interface com.linkedin.venice.serializer.RecordSerializer
 
serializeObjects(Iterable<T>, ByteBuffer) - Method in interface com.linkedin.venice.serializer.RecordSerializer
Serialize a list of objects and put the prefix before the serialized objects.
SerializerDeserializerFactory - Class in com.linkedin.venice.serializer
For one given store, the client only needs the followings: 1.
SerializerDeserializerFactory() - Constructor for class com.linkedin.venice.serializer.SerializerDeserializerFactory
 
SerializerDeserializerFactory.SchemaPairAndClassContainer - Class in com.linkedin.venice.serializer
 
serializeRecord(Object, Schema) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
 
serializeRmdRecord(int, GenericRecord) - Method in class com.linkedin.davinci.replication.merge.RmdSerDe
 
serializeRouterRequest() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
serializeRouterRequest() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
serializeRouterRequest() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
For multi-get requests, simply serialize the set of RouterKey to bytes; for read compute requests, concatenate the compute request and the serialized keys
serializeStoreVersionState(String, StoreVersionState) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
SERVER - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
SERVER - Static variable in class com.linkedin.venice.acl.VeniceComponent
 
SERVER_ACL_APPROVED_ATTRIBUTE_KEY - Static variable in class com.linkedin.venice.listener.ServerAclHandler
 
SERVER_ADMIN_RESPONSE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Response record for admin request.
SERVER_BASED_METADATA - com.linkedin.venice.fastclient.meta.StoreMetadataFetchMode
Fast-client will make API calls to storage-nodes to get metadata information
SERVER_BLOCKING_QUEUE_TYPE - Static variable in class com.linkedin.venice.ConfigKeys
Check the available types in com.linkedin.venice.config.BlockingQueueType
SERVER_COMPUTE_FAST_AVRO_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable fast-avro in compute request path.
SERVER_COMPUTE_QUEUE_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
SERVER_COMPUTE_THREAD_NUM - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_CONFIG_FILE_NAME - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
SERVER_CONSUMER_POOL_SIZE_PER_KAFKA_CLUSTER - Static variable in class com.linkedin.venice.ConfigKeys
Consumer pool size per Kafka cluster.
SERVER_DATABASE_CHECKSUM_VERIFICATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
whether to enable checksum verification in the ingestion path from kafka to database persistency.
SERVER_DATABASE_LOOKUP_QUEUE_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
The following config is used to control the maximum database lookup requests queued, when the queue is full, server will propagate the back pressure to the caller.
SERVER_DATABASE_MEMORY_STATS_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_DATABASE_SYNC_BYTES_INTERNAL_FOR_DEFERRED_WRITE_MODE - Static variable in class com.linkedin.venice.ConfigKeys
Database sync per bytes for deferred-write mode.
SERVER_DATABASE_SYNC_BYTES_INTERNAL_FOR_TRANSACTIONAL_MODE - Static variable in class com.linkedin.venice.ConfigKeys
Database sync per bytes for transactional mode.
SERVER_DB_READ_ONLY_FOR_BATCH_ONLY_STORE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_DEBUG_LOGGING_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to print logs that are used for troubleshooting only.
SERVER_DEDICATED_CONSUMER_POOL_FOR_AA_WC_LEADER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Handling AA or WC stores is expensive because of RocksDB lookup, and this following feature will handle these writes in dedicated consumer pool, so that the full updates won't be affected by the heavy writes to these AA/WC stores.
SERVER_DEDICATED_CONSUMER_POOL_SIZE_FOR_AA_WC_LEADER - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_DEDICATED_DRAINER_FOR_SORTED_INPUT_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Use a seprate drainer queue for sorted ingestion and un-sorted ingestion.
SERVER_DISK_FULL_THRESHOLD - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_DISK_HEALTH_CHECK_INTERVAL_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
This config decides the frequency of the disk health check; the disk health check service writes 64KB data to a temporary file in the database directory and read from the file for each health check.
SERVER_DISK_HEALTH_CHECK_SERVICE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to enable/disable the disk health check service.
SERVER_DISK_HEALTH_CHECK_TIMEOUT_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
When there is an actual disk failure, health check operation would hang, so this config decides how fast the servers will start reporting unhealthy after the health check stop updating status; however, in order to reduce the possibility of false alerts (for example, the health check updates can be delayed by GC), we couldn't set the timeout too small.
SERVER_ENABLE_LIVE_CONFIG_BASED_KAFKA_THROTTLING - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_ENABLE_PARALLEL_BATCH_GET - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable parallel lookup for batch-get.
SERVER_FORKED_PROCESS_JVM_ARGUMENT_LIST - Static variable in class com.linkedin.venice.ConfigKeys
A list of JVM arguments for forked child process, separated by semicolon.
SERVER_HTTP2_HEADER_TABLE_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Allows the sender to inform the remote endpoint of the maximum size of the header compression table used to decode header blocks, in octets.
SERVER_HTTP2_INBOUND_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to support http/2 inbound request.
SERVER_HTTP2_INITIAL_WINDOW_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Indicates the sender's initial window size (in octets) for stream-level flow control.
SERVER_HTTP2_MAX_CONCURRENT_STREAMS - Static variable in class com.linkedin.venice.ConfigKeys
Indicates the maximum number of concurrent streams that the sender will allow.
SERVER_HTTP2_MAX_FRAME_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Indicates the size of the largest frame payload that the sender is willing to receive, in octets.
SERVER_HTTP2_MAX_HEADER_LIST_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
This advisory setting informs a peer of the maximum size of header list that the sender is prepared to accept, in octets.
SERVER_INCREMENTAL_PUSH - com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
 
SERVER_INCREMENTAL_PUSH_PREFIX - Static variable in class com.linkedin.venice.common.PushStatusStoreUtils
 
SERVER_INGESTION_CHECKPOINT_DURING_GRACEFUL_SHUTDOWN_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
A config to control graceful shutdown.
SERVER_INGESTION_HEARTBEAT_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
The time interval in milliseconds for leader replica to send heartbeat to RT topic for consumers (including the leader) to keep its latest processed upstream RT offset up-to-date in case when the RT topic ends with SOS, EOS or skipped records.
SERVER_INGESTION_ISOLATION_ACL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_INGESTION_ISOLATION_APPLICATION_PORT - Static variable in class com.linkedin.venice.ConfigKeys
Service listening port number for forked ingestion process.
SERVER_INGESTION_ISOLATION_CONNECTION_TIMEOUT_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Timeout for connection between main process and forked ingestion process.
SERVER_INGESTION_ISOLATION_HEARTBEAT_REQUEST_TIMEOUT_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Timeout for single heartbeat request sent from main process to forked ingestion process.
SERVER_INGESTION_ISOLATION_METRIC_REQUEST_TIMEOUT_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Timeout for single metric request sent from main process to forked ingestion process.
SERVER_INGESTION_ISOLATION_PRINCIPAL_NAME - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_INGESTION_ISOLATION_REQUEST_TIMEOUT_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Timeout for single ingestion command request sent from main process to forked ingestion process.
SERVER_INGESTION_ISOLATION_SERVICE_PORT - Static variable in class com.linkedin.venice.ConfigKeys
Service listening port number for main ingestion service.
SERVER_INGESTION_ISOLATION_SSL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_INGESTION_ISOLATION_STATS_CLASS_LIST - Static variable in class com.linkedin.venice.ConfigKeys
A list of fully-qualified class names of all stats classes that needs to be initialized in isolated ingestion process, separated by comma.
SERVER_INGESTION_MODE - Static variable in class com.linkedin.venice.ConfigKeys
Ingestion mode in target storage instance.
SERVER_INGESTION_TASK_MAX_IDLE_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_KAFKA_CONSUMER_OFFSET_COLLECTION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Enable offset collection for kafka topic partition from kafka consumer metrics.
SERVER_KAFKA_FETCH_QUOTA_RECORDS_PER_SECOND - com.linkedin.venice.Arg
 
SERVER_KAFKA_FETCH_QUOTA_RECORDS_PER_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
How many records that one server could consume from Kafka at most in one second from the specified regions.
SERVER_KAFKA_FETCH_QUOTA_RECORDS_PER_SECOND - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
How many records that one server could consume from Kafka at most in one second from the specified regions.
SERVER_KAFKA_MAX_POLL_RECORDS - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to control the maximum records returned by every poll request.
SERVER_LEADER_COMPLETE_STATE_CHECK_IN_FOLLOWER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to check LeaderCompleteState in the follower replica and davinci replica before marking the follower completed.
SERVER_LEADER_COMPLETE_STATE_CHECK_IN_FOLLOWER_VALID_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
Follower replicas and DavinciClient will only consider heartbeats received within this time window to mark themselves as completed.
SERVER_LEAKED_RESOURCE_CLEAN_UP_INTERVAL_IN_MINUTES - Static variable in class com.linkedin.venice.ConfigKeys
When a BDB partition is dropped, the disk space is not released immediately; a checkpoint is needed to release the disk space; so a cleaner thread is spawned for the entire storage service; the cleaner thread will wake up every few hours and check whether it needs to do a checkpoint; if so, clean up each store sequentially.
SERVER_LEAKED_RESOURCE_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable leaked resource cleanup in storage node.
SERVER_LOCAL_CONSUMER_CONFIG_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
Any server config that start with "server.local.consumer.config.prefix" will be used as a customized consumer config for local consumer.
SERVER_MAX_REQUEST_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_MAX_WAIT_FOR_VERSION_INFO_MS_CONFIG - Static variable in class com.linkedin.venice.ConfigKeys
Maximum duration (in milliseconds) to wait for the version information to become available in the store metadata repository before skipping Heartbeat (HB) lag monitor setup activity during state transition.
SERVER_METADATA_RESPONSE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Response record for metadata fetch request.
SERVER_NETTY_GRACEFUL_SHUTDOWN_PERIOD_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_NETTY_IDLE_TIME_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_NETTY_WORKER_THREADS - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_NODE_CAPACITY_RCU - Static variable in class com.linkedin.venice.ConfigKeys
Number of Read Capacity Units per second that the node can handle across all stores.
SERVER_NON_EXISTING_TOPIC_CHECK_RETRY_INTERNAL_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
The config will work together with ConfigKeys.SERVER_NON_EXISTING_TOPIC_INGESTION_TASK_KILL_THRESHOLD_SECOND to decide whether a certain ingestion task should be killed or not.
SERVER_NON_EXISTING_TOPIC_INGESTION_TASK_KILL_THRESHOLD_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
When to kill the ingestion task if the topic doesn't exist for the configured period of time.
SERVER_NUM_SCHEMA_FAST_CLASS_WARMUP - Static variable in class com.linkedin.venice.ConfigKeys
Number of value schemas for which fast avro classes are generated for read-compute stores before push completion is reported.
SERVER_OPTIMIZE_DATABASE_FOR_BACKUP_VERSION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
A config to control whether VeniceServer will optimize the database for the backup version to free up memory resources occupied.
SERVER_OPTIMIZE_DATABASE_FOR_BACKUP_VERSION_NO_READ_THRESHOLD_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
A config to control the no read threshold when the database optimization should kick in.
SERVER_OPTIMIZE_DATABASE_SERVICE_SCHEDULE_INTERNAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Schedule interval for database optimization service.
SERVER_PARALLEL_BATCH_GET_CHUNK_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Chunk size of each task for parallel lookup of batch-get.
SERVER_PARTITION_GRACEFUL_DROP_DELAY_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
When load balance happens, a replica could be moved to another storage node.
SERVER_PROMOTION_TO_LEADER_REPLICA_DELAY_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
In Leader/Follower state transition model, in order to avoid split brain problem (multiple leaders) as much as possible, the newly promoted leader should keep checking whether there is any new messages from the old leader in the version topic, and wait for some time (5 minutes by default) after the last message consumed before switching to leader role and potential starts producing to the version topic.
SERVER_PROPERTIES_FILE - Static variable in class com.linkedin.davinci.config.VeniceConfigLoader
 
SERVER_PUBSUB_CONSUMER_POLL_RETRY_BACKOFF_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to control the backoff time between PubSub consumer poll retries.
SERVER_PUBSUB_CONSUMER_POLL_RETRY_TIMES - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to control how many times PubSub consumer would retry polling during ingestion when RetriableException happens.
SERVER_QUOTA_ENFORCEMENT_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Set to true to enable enforcement of quota by the storage node
SERVER_RECORD_LEVEL_METRICS_WHEN_BOOTSTRAPPING_CURRENT_VERSION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable record-level metrics when bootstrapping current version.
SERVER_REMOTE_CONSUMER_CONFIG_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
Any server config that start with "server.remote.consumer.config.prefix" will be used as a customized consumer config for remote consumer.
SERVER_REMOTE_INGESTION_REPAIR_SLEEP_INTERVAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_REST_SERVICE_EPOLL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable epoll in rest service layer.
SERVER_REST_SERVICE_STORAGE_THREAD_NUM - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_ROCKSDB_STORAGE_CONFIG_CHECK_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable to check the RocksDB storage type used to open the RocksDB storage engine and how it was built.
SERVER_ROUTER_CONNECTION_WARMING_DELAY_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to control how much time Server will wait for connection warming from Routers.
SERVER_SCHEMA_FAST_CLASS_WARMUP_TIMEOUT - Static variable in class com.linkedin.venice.ConfigKeys
Timeout duration of schema generation for fast class warmup period
SERVER_SCHEMA_PRESENCE_CHECK_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
This indicates if server will perform the schema presence check or not.
SERVER_SHARED_CONSUMER_ASSIGNMENT_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable partition wise balanced shared consumer assignment.
SERVER_SHARED_CONSUMER_NON_EXISTING_TOPIC_CLEANUP_DELAY_MS - Static variable in class com.linkedin.venice.ConfigKeys
This config is used to control how much time we should wait before cleaning up the corresponding ingestion task when an non-existing topic is discovered.
SERVER_SHUTDOWN_DISK_UNHEALTHY_TIME_MS - Static variable in class com.linkedin.venice.ConfigKeys
A time after which a bad SSD will trigger server shutdown.
SERVER_SOURCE_TOPIC_OFFSET_CHECK_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
 
SERVER_SSL_HANDSHAKE_QUEUE_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the queue capacity for the thread pool executor used for ssl handshake in servers.
SERVER_SSL_HANDSHAKE_THREAD_POOL_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
Config to control the number of threads in the thread pool executor used for ssl handshake in servers.
SERVER_STOP_CONSUMPTION_TIMEOUT_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
Number of retries allowed for stopConsumptionAndWait() API in StoreIngestionService.
SERVER_STORE_TO_EARLY_TERMINATION_THRESHOLD_MS_MAP - Static variable in class com.linkedin.venice.ConfigKeys
The request early termination threshold map: The key will be store name, and the value will be the actual threshold.
SERVER_STUCK_CONSUMER_REPAIR_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to enable stuck consumer repair in Server.
SERVER_STUCK_CONSUMER_REPAIR_INTERVAL_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
Server stuck consumer detection interval.
SERVER_STUCK_CONSUMER_REPAIR_THRESHOLD_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
Server stuck consumer repair threshold.
SERVER_SYSTEM_STORE_PROMOTION_TO_LEADER_REPLICA_DELAY_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
The system store, such as replica status related requires fast leadership fail over to avoid the stable info in system store, which could affect the request routing in the read path.
SERVER_UNSUB_AFTER_BATCHPUSH - Static variable in class com.linkedin.venice.ConfigKeys
Unsubscribe from kakfa topic once a batch-store push finishes
SERVER_URL - com.linkedin.venice.Arg
 
ServerAclHandler - Class in com.linkedin.venice.listener
Together with ServerStoreAclHandler, Server will allow two kinds of access pattern: 1.
ServerAclHandler(StaticAccessController) - Constructor for class com.linkedin.venice.listener.ServerAclHandler
 
ServerAclHandler(StaticAccessController, boolean) - Constructor for class com.linkedin.venice.listener.ServerAclHandler
 
ServerAdminAction - Enum in com.linkedin.venice.meta
 
serverConfig - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
serverConfigs - Variable in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
All server configs in runtime
ServerConfigSnapshot - Class in com.linkedin.venice.admin.protocol.response
 
ServerConfigSnapshot() - Constructor for class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
Default constructor.
ServerConfigSnapshot(Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
All-args constructor.
ServerConnectionStats - Class in com.linkedin.venice.stats
 
ServerConnectionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.ServerConnectionStats
 
ServerConnectionStatsHandler - Class in com.linkedin.venice.listener
 
ServerConnectionStatsHandler(ServerConnectionStats, String) - Constructor for class com.linkedin.venice.listener.ServerConnectionStatsHandler
 
ServerCurrentVersionResponse - Class in com.linkedin.davinci.listener.response
 
ServerCurrentVersionResponse() - Constructor for class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
 
ServerHandlerUtils - Class in com.linkedin.venice.listener
 
ServerHandlerUtils() - Constructor for class com.linkedin.venice.listener.ServerHandlerUtils
 
serverHttp2FrameCodecBuilder() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
ServerHttpRequestStats - Class in com.linkedin.venice.stats
ServerHttpRequestStats contains a list of counters in order to mainly measure the performance of handling requests from Routers.
ServerHttpRequestStats(MetricsRepository, String, RequestType, boolean, ServerHttpRequestStats, boolean) - Constructor for class com.linkedin.venice.stats.ServerHttpRequestStats
 
ServerMetadataServiceStats - Class in com.linkedin.davinci.stats
 
ServerMetadataServiceStats(MetricsRepository) - Constructor for class com.linkedin.davinci.stats.ServerMetadataServiceStats
 
ServerQuotaTokenBucketStats - Class in com.linkedin.venice.stats
Quota-related metrics that are extracted from the TokenBuckets
ServerQuotaTokenBucketStats(MetricsRepository, String, Supplier<TokenBucket>) - Constructor for class com.linkedin.venice.stats.ServerQuotaTokenBucketStats
 
ServerQuotaUsageStats - Class in com.linkedin.venice.stats
for measuring requests and quota rejections for each store
ServerQuotaUsageStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.ServerQuotaUsageStats
 
ServerReadMetadataRepository - Class in com.linkedin.venice.listener
A wrapper that holds reference for various repositories responsible for constructing metadata responses upon request.
ServerReadMetadataRepository(MetricsRepository, ReadOnlyStoreRepository, ReadOnlySchemaRepository, Optional<CompletableFuture<HelixCustomizedViewOfflinePushRepository>>, Optional<CompletableFuture<HelixInstanceConfigRepository>>) - Constructor for class com.linkedin.venice.listener.ServerReadMetadataRepository
 
serverSocketChannel() - Method in enum com.linkedin.alpini.netty4.misc.NettyUtils.Mode
 
serverSocketChannel() - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
serverSocketChannel(Class<?>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
serverSocketChannel(Class<?>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
serverSocketOptions(String, Object) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
serverSocketOptions(String, Object) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
serverSocketOptions(Map<String, Object>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
serverSocketOptions(Map<String, Object>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
ServerStatsContext - Class in com.linkedin.venice.listener
We need to be able to record server side statistics for gRPC requests.
ServerStatsContext(AggServerHttpRequestStats, AggServerHttpRequestStats, AggServerHttpRequestStats) - Constructor for class com.linkedin.venice.listener.ServerStatsContext
 
ServerStoreAclHandler - Class in com.linkedin.venice.listener
Together with ServerAclHandler, Server will allow two kinds of access pattern: 1.
ServerStoreAclHandler(DynamicAccessController, ReadOnlyStoreRepository) - Constructor for class com.linkedin.venice.listener.ServerStoreAclHandler
 
SERVICE_FACTORY - Static variable in interface com.linkedin.alpini.base.registry.ShutdownableExecutors
 
SERVICE_NAME - Static variable in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
 
SERVICE_UNAVAILABLE - Static variable in class com.linkedin.venice.grpc.GrpcErrorCodes
 
ServiceDiscoveryAnnouncer - Interface in com.linkedin.venice.servicediscovery
This interface is used to announce the service to a Service Discovery system on startup and de-announce the service on graceful shutdown.
ServiceDiscoveryException - Exception in com.linkedin.venice.client.exceptions
 
ServiceDiscoveryException(String) - Constructor for exception com.linkedin.venice.client.exceptions.ServiceDiscoveryException
 
ServiceDiscoveryException(String, Throwable) - Constructor for exception com.linkedin.venice.client.exceptions.ServiceDiscoveryException
 
ServiceDiscoveryException(Throwable) - Constructor for exception com.linkedin.venice.client.exceptions.ServiceDiscoveryException
 
serviceState - Variable in class com.linkedin.venice.service.AbstractVeniceService
 
serviceUnavailable() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
serviceUnavailable() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
sessionContext(boolean) - Method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
 
sessionContext(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
set(int, E) - Method in class com.linkedin.venice.utils.SparseConcurrentList
A function which behaves like Map.put(Object, Object), rather than List.set(int, Object).
set(int, E) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
set(HttpHeaders) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
set(CharSequence, int) - Method in interface com.linkedin.alpini.base.misc.Headers
 
set(CharSequence, int) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
set(CharSequence, long) - Method in interface com.linkedin.alpini.base.misc.Headers
 
set(CharSequence, Iterable<?>) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
set(CharSequence, Object) - Method in interface com.linkedin.alpini.base.misc.Headers
 
set(CharSequence, Object) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
set(CharSequence, Object) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
set(Iterable<Map.Entry<String, String>>) - Method in interface com.linkedin.alpini.base.misc.Headers
 
set(Iterable<Map.Entry<String, String>>) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
 
set(String, Iterable<?>) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
set(String, Object) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
set(T) - Method in class com.linkedin.alpini.base.misc.SoftThreadLocal
Sets the current thread's copy of this thread-local variable to the specified value.
set(T) - Method in class com.linkedin.venice.utils.ConcurrentRef
 
set(V) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
SET_DIFF - Static variable in class com.linkedin.venice.schema.writecompute.WriteComputeConstants
 
SET_MIGRATION_PUSH_STRATEGY - com.linkedin.venice.Command
 
SET_MIGRATION_PUSH_STRATEGY - com.linkedin.venice.controllerapi.ControllerRoute
 
SET_OWNER - com.linkedin.venice.Command
 
SET_OWNER - com.linkedin.venice.controllerapi.ControllerRoute
 
SET_PARTITION_COUNT - com.linkedin.venice.Command
 
SET_PARTITION_COUNT - com.linkedin.venice.controllerapi.ControllerRoute
 
SET_STORE_CURRENT_VERSION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
SET_STORE_OWNER - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
SET_STORE_PARTITION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
SET_TOPIC_COMPACTION - com.linkedin.venice.controllerapi.ControllerRoute
 
SET_UNION - Static variable in class com.linkedin.venice.schema.writecompute.WriteComputeConstants
 
SET_VERSION - com.linkedin.venice.Command
 
SET_VERSION - com.linkedin.venice.controllerapi.ControllerRoute
 
setAcceptConnection(boolean) - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
setAcceptConnection(boolean) - Method in interface com.linkedin.alpini.router.impl.Router
 
setAccessControlled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'accessControlled' field.
setAccessControlled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setAccessControlled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setAccessControlled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setAccessControlled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setAccessControlled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setAccessControlled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
Deprecated.
The store level accessControlled flag is no longer valid to be used to skip ACL checks.
setAccessControlled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'accessControlled' field.
setAccessControlled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'accessControlled' field.
setAccessController(DynamicAccessController) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setAccessPermissions(String) - Method in class com.linkedin.venice.controllerapi.AclResponse
 
setAcls(AclBinding) - Method in interface com.linkedin.venice.authorization.AuthorizerService
This will set the AceEntries in provided AclBinding object to be the current set of ACL's for the resource.
setAcls(AclBinding) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
setAclsCounter - Variable in class com.linkedin.venice.controller.MockVeniceAuthorizer
 
setAcquireTimeoutAction(FixedChannelPool.AcquireTimeoutAction) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'activeActiveReplicationEnabled' field.
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setActiveActiveReplicationEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setActiveActiveReplicationEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'activeActiveReplicationEnabled' field.
setActiveActiveReplicationEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'activeActiveReplicationEnabled' field.
setActiveElementTimestamps(List<Long>) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
setAdminConsumerService(String, AdminConsumerService) - Method in interface com.linkedin.venice.controller.Admin
 
setAdminConsumerService(String, AdminConsumerService) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
setAdminConsumerService(String, AdminConsumerService) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
setAdminConsumptionCheckpointOffset(long) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
setAdminConsumptionFailedOffset(long) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
setAdminConsumptionOffsetLag(long) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
setAge(Duration) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setAge(Duration) - Method in interface com.linkedin.venice.meta.Version
 
setAge(Duration) - Method in class com.linkedin.venice.meta.VersionImpl
 
setAggKafkaConsumerService(AggKafkaConsumerService) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setAggregatedMetrics(Map<CharSequence, Double>) - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
Sets the value of the 'aggregatedMetrics' field.
setAggregates(Map<CharSequence, Long>) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'aggregates' field.
setAll(HttpHeaders) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
setAllowEmptyDelegateInitializationToSucceed() - Method in class com.linkedin.venice.controller.init.DelegatingClusterLeaderInitializationRoutine
 
setAllowGeneratingSelfSignedCertificate(boolean) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setAlwaysOnDeserializerNumberOfThreads(int) - Method in class com.linkedin.venice.client.store.ClientConfig
Deprecated.
setAlwaysOnDeserializerQueueCapacity(int) - Method in class com.linkedin.venice.client.store.ClientConfig
Deprecated.
setAmplificationFactor(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
Sets the value of the 'amplificationFactor' field.
setAmplificationFactor(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setAmplificationFactor(int) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setAmplificationFactor(int) - Method in interface com.linkedin.venice.meta.PartitionerConfig
 
setAmplificationFactor(int) - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
setAmplificationFactor(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
Sets the value of the 'amplificationFactor' field.
setAmplificationFactor(int) - Method in class com.linkedin.venice.metadata.response.VersionProperties
Sets the value of the 'amplificationFactor' field.
setAmplificationFactor(int) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
Sets the value of the 'amplificationFactor' field.
setApplyTargetVersionFilterForIncPush(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'applyTargetVersionFilterForIncPush' field.
setApplyTargetVersionFilterForIncPush(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'applyTargetVersionFilterForIncPush' field.
setAsyncStoreInitSleepIntervalMs(long) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
setAttributeMap(AttributeMap) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
 
setAuditMap(Map<String, StoreDataAudit>) - Method in class com.linkedin.venice.controllerapi.ClusterStaleDataAuditResponse
 
setAuthorizerService(AuthorizerService) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setAutoSchemaPushJobEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setBackupStrategy(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'backupStrategy' field.
setBackupStrategy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'backupStrategy' field.
setBackupStrategy(BackupStrategy) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setBackupStrategy(BackupStrategy) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setBackupStrategy(BackupStrategy) - Method in interface com.linkedin.venice.meta.Store
 
setBackupStrategy(BackupStrategy) - Method in class com.linkedin.venice.meta.StoreInfo
 
setBackupStrategy(BackupStrategy) - Method in class com.linkedin.venice.meta.SystemStore
 
setBackupStrategy(BackupStrategy) - Method in class com.linkedin.venice.meta.ZKStore
 
setBackupStrategy(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'backupStrategy' field.
setBackupVersionRetentionMs(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'backupVersionRetentionMs' field.
setBackupVersionRetentionMs(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setBackupVersionRetentionMs(long) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setBackupVersionRetentionMs(long) - Method in interface com.linkedin.venice.meta.Store
 
setBackupVersionRetentionMs(long) - Method in class com.linkedin.venice.meta.StoreInfo
 
setBackupVersionRetentionMs(long) - Method in class com.linkedin.venice.meta.SystemStore
 
setBackupVersionRetentionMs(long) - Method in class com.linkedin.venice.meta.ZKStore
 
setBackupVersionRetentionMs(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'backupVersionRetentionMs' field.
setBatchConflictResolutionPolicy(int) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'batchConflictResolutionPolicy' field.
setBatchDeserializerType(BatchDeserializerType) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setBatchGetLimit(int) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setBatchGetLimit(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'batchGetLimit' field.
setBatchGetLimit(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setBatchGetLimit(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setBatchGetLimit(int) - Method in interface com.linkedin.venice.meta.Store
 
setBatchGetLimit(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setBatchGetLimit(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setBatchGetLimit(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setBatchGetLimit(int) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'batchGetLimit' field.
setBatchGetLimit(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'batchGetLimit' field.
setBatchGetLimit(Integer) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'batchGetLimit' field.
setBatchGetRouterCacheEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'batchGetRouterCacheEnabled' field.
setBatchGetRouterCacheEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setBatchGetRouterCacheEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'batchGetRouterCacheEnabled' field.
setBenignLeaderOffsetRewindCount(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setBenignLeaderProducerFailure(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'blobTransferEnabled' field.
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setBlobTransferEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setBlobTransferEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'blobTransferEnabled' field.
setBlobTransferEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'blobTransferEnabled' field.
setBlobTransferEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'blobTransferEnabled' field.
setBlock(boolean) - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
setBlockBaseFormatVersion(int) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
setBlockTransition(boolean) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
 
setBootstrapFileSystemPath(String) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setBootstrapToOnlineTimeoutInHours(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'bootstrapToOnlineTimeoutInHours' field.
setBootstrapToOnlineTimeoutInHours(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setBootstrapToOnlineTimeoutInHours(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setBootstrapToOnlineTimeoutInHours(int) - Method in interface com.linkedin.venice.meta.Store
 
setBootstrapToOnlineTimeoutInHours(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setBootstrapToOnlineTimeoutInHours(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setBootstrapToOnlineTimeoutInHours(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setBootstrapToOnlineTimeoutInHours(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'bootstrapToOnlineTimeoutInHours' field.
setBootstrapToOnlineTimeoutInHours(Integer) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'bootstrapToOnlineTimeoutInHours' field.
setBrokerAddress(String) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setBufferReplayEnabledForHybrid(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setBufferReplayEnabledForHybrid(boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'bufferReplayEnabledForHybrid' field.
setBufferReplayEnabledForHybrid(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setBufferReplayEnabledForHybrid(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setBufferReplayEnabledForHybrid(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'bufferReplayEnabledForHybrid' field.
setBufferReplayForHybridForVersion(int, boolean) - Method in class com.linkedin.venice.meta.AbstractStore
 
setBufferReplayForHybridForVersion(int, boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setBufferReplayForHybridForVersion(int, boolean) - Method in interface com.linkedin.venice.meta.Store
 
setBufferReplayPolicy(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Sets the value of the 'bufferReplayPolicy' field.
setBufferReplayPolicy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Sets the value of the 'bufferReplayPolicy' field.
setBuilder() - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
setBusyAutoReadDisable(boolean) - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
setBusyAutoReadDisable(Router, boolean) - Static method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
setByteRate(double) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
setBytes(byte[]) - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
 
setBytes(int, byte[], int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
setBytes(int, ByteBuf, int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
setBytes(int, InputStream, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
setBytes(int, ByteBuffer) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
setBytes(int, FileChannel, long, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
setBytes(int, ScatteringByteChannel, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
setCacheConfig(ObjectCacheConfig) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
setCallback(PubSubProducerCallback) - Method in class com.linkedin.venice.writer.CompletableFutureCallback
 
setChannelReuse(boolean) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
setCheckpointLocalVersionTopicOffset(long) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setCheckpointUpstreamVersionTopicOffset(long) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setChecksumState(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'checksumState' field.
setChecksumType(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
Sets the value of the 'checksumType' field.
setChecksumType(int) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'checksumType' field.
setChecksumValue(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
Sets the value of the 'checksumValue' field.
setChildControllerAdminTopicConsumptionEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
setChildControllerAdminTopicConsumptionEnabled(boolean) - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
setChildDataCenterControllerD2Map(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
 
setChildDataCenterControllerUrlMap(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
 
setChildren(List<PropertyKey>, List<T>) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
setChunk(int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.ChunkedValueInputStream
 
setChunked(boolean) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Sets the value of the 'chunked' field.
setChunked(boolean) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'chunked' field.
setChunkedKeySuffix(ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Sets the value of the 'chunkedKeySuffix' field.
setChunkedWriteHandler(ChannelHandlerContext, VeniceChunkedWriteHandler, RouterStats<AggRouterHttpRequestStats>) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setChunkId(ChunkId) - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
Sets the value of the 'chunkId' field.
setChunkIndex(int) - Method in class com.linkedin.venice.storage.protocol.ChunkId
Sets the value of the 'chunkIndex' field.
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'chunkingEnabled' field.
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setChunkingEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'chunkingEnabled' field.
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setChunkingEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'chunkingEnabled' field.
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'chunkingEnabled' field.
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'chunkingEnabled' field.
setChunkingEnabled(boolean) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setChunkingEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'chunkingEnabled' field.
setChunkingInfo(byte[], ByteBuffer[], ChunkedValueManifest, ByteBuffer[], ChunkedValueManifest, ChunkedValueManifest, ChunkedValueManifest) - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
 
setChunkingInfo(byte[], ByteBuffer[], ChunkedValueManifest, ByteBuffer[], ChunkedValueManifest, ChunkedValueManifest, ChunkedValueManifest) - Method in interface com.linkedin.venice.writer.ChunkAwareCallback
For all PUT operations, the {@param key} is guaranteed to be passed via this function, whether chunking is enabled or not, and whether the value is chunked or not.
setCiphers(String...) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Assigns enabled ciphers.
setClientConfigForConsumer(ClientConfig) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setClientDecompressionEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'clientDecompressionEnabled' field.
setClientDecompressionEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setClientDecompressionEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setClientDecompressionEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setClientDecompressionEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setClientDecompressionEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setClientDecompressionEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setClientDecompressionEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'clientDecompressionEnabled' field.
setClientDecompressionEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'clientDecompressionEnabled' field.
setClientRoutingStrategyType(ClientRoutingStrategyType) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setCluster(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Sets the value of the 'cluster' field.
setCluster(String) - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
setCluster(String) - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
 
setCluster(String) - Method in class com.linkedin.venice.datarecovery.Command.Result
 
setCluster(String) - Method in class com.linkedin.venice.meta.StoreConfig
 
setClusterDiscoveryD2Service(String) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Sets the value of the 'clusterName' field.
setClusterName(CharSequence) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'clusterName' field.
setClusterName(String) - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
setColoStatus(Map<CharSequence, List<PushJobDetailsStatusTuple>>) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'coloStatus' field.
setColoToCurrentVersions(Map<String, Integer>) - Method in class com.linkedin.venice.meta.StoreInfo
 
setCommand(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setCommandType(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
Sets the value of the 'commandType' field.
setComplete(T, Throwable) - Method in interface com.linkedin.alpini.base.concurrency.AsyncPromise
 
setCompleted() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setCompletionReported(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'completionReported' field.
setComponentType(int) - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
Sets the value of the 'componentType' field.
setCompressionDictionary(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Sets the value of the 'compressionDictionary' field.
setCompressionDictionary(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'compressionDictionary' field.
setCompressionDictSize(int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setCompressionStrategy(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'compressionStrategy' field.
setCompressionStrategy(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Sets the value of the 'compressionStrategy' field.
setCompressionStrategy(int) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'compressionStrategy' field.
setCompressionStrategy(int) - Method in class com.linkedin.venice.metadata.response.VersionProperties
Sets the value of the 'compressionStrategy' field.
setCompressionStrategy(int) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 compressionStrategy = 3;
setCompressionStrategy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'compressionStrategy' field.
setCompressionStrategy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'compressionStrategy' field.
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setCompressionStrategy(CompressionStrategy) - Method in interface com.linkedin.venice.meta.Store
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.meta.StoreInfo
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.meta.SystemStore
 
setCompressionStrategy(CompressionStrategy) - Method in interface com.linkedin.venice.meta.Version
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.meta.VersionImpl
 
setCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.meta.ZKStore
 
setCompressionStrategy(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'compressionStrategy' field.
setCompressionStrategy(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'compressionStrategy' field.
setCompressorFactory(StorageEngineBackedCompressorFactory) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setComputedAggregates(List<Long>) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
Sets the value of the 'computedAggregates' field.
setConfig(RoutersClusterConfig) - Method in class com.linkedin.venice.controllerapi.RoutersClusterConfigResponse
 
setConfigMap(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
Sets the value of the 'configMap' field.
setConfigs(StoreProperties) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Sets the value of the 'configs' field.
setConnectionLimit(int) - Method in class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
Set the maximum number of connections.
setConsumer(PubSubConsumerAdapter) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
 
setConsumeRemotely(boolean) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setConsumeRemotely(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'consumeRemotely' field.
setConsumerIdx(int) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
setConsumerName(String) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setConsumerProperties(Properties) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setContinueExistingPeriodicTasksAfterShutdownPolicy(boolean) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Sets the policy on whether to continue executing existing periodic tasks even when this executor has been shutdown.
setControllerClient(ControllerClient) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
setControllerClient(D2ControllerClient) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
setControllerD2ServiceName(String) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setControllerRequestRetryCount(int) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setControlMessageType(int) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
Sets the value of the 'controlMessageType' field.
setControlMessageUnion(Object) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
Sets the value of the 'controlMessageUnion' field.
setCoreWorkDone(boolean) - Method in class com.linkedin.venice.datarecovery.Command.Result
 
setCorruptedMsg(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setCosineSimilarityCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setCosineSimilarityCount(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setCosSimilarityParam(List<Float>) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
Sets the value of the 'cosSimilarityParam' field.
setCountOperatorCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setCountOperatorCount(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setCreatedTime(long) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'createdTime' field.
setCreatedTime(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'createdTime' field.
setCreatedTime(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'createdTime' field.
setCreationTime(long) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'creationTime' field.
setCredentials(ServerCredentials) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setCurrentOffset(long) - Method in class com.linkedin.venice.meta.UncompletedReplica
 
setCurrentProgress(long) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
setCurrentStats(int, STATS) - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
setCurrentStatus(ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setCurrentStatus(ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
setCurrentStatus(ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.RouterBasedPushMonitor
 
setCurrentStatus(HybridStoreQuotaStatus) - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
 
setCurrentValue(ValueBytes) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Sets the value of the 'currentValue' field.
setCurrentVersion(int) - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
 
setCurrentVersion(int) - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
setCurrentVersion(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
Sets the value of the 'currentVersion' field.
setCurrentVersion(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'currentVersion' field.
setCurrentVersion(int) - Method in class com.linkedin.venice.controllerapi.CurrentVersionResponse
 
setCurrentVersion(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setCurrentVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setCurrentVersion(int) - Method in interface com.linkedin.venice.meta.Store
 
setCurrentVersion(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setCurrentVersion(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
Sets the value of the 'currentVersion' field.
setCurrentVersion(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setCurrentVersion(int) - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
setCurrentVersion(int) - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
setCurrentVersion(int) - Method in class com.linkedin.venice.meta.ZKStore
Set current serving version number of this store.
setCurrentVersion(int) - Method in class com.linkedin.venice.metadata.response.VersionProperties
Sets the value of the 'currentVersion' field.
setCurrentVersion(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'currentVersion' field.
setCurrentVersion(int) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Sets the value of the 'currentVersion' field.
setCurrentVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
setCurrentVersion(Integer) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setCurrentVersion(Integer) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'currentVersion' field.
setCurrentVersionStates(List<StoreVersionState>) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
Sets the value of the 'currentVersionStates' field.
setCurrentVersionWithoutCheck(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setCurrentVersionWithoutCheck(int) - Method in interface com.linkedin.venice.meta.Store
 
setCurrentVersionWithoutCheck(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setCurrentVersionWithoutCheck(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setCustomizedStateProvider(CustomizedStateProvider) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
Only used in test now
setD2BasePath(String) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setD2Client(D2Client) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setD2Client(D2Client) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setD2Client(D2Client) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setD2Client(D2Client) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setD2Client(String, D2Client) - Static method in class com.linkedin.venice.d2.D2ClientFactory
 
setD2ControllerClient(D2ControllerClient) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setD2ControllerClient(D2ControllerClient) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
 
setD2Service(String) - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
setD2ServiceDiscovery(D2ServiceDiscovery) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
Used for test only
setD2ServiceName(String) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setD2ServiceName(String) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setD2ServiceName(String) - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
 
setD2ZkTimeout(int) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setData(ByteString) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
bytes data = 2;
setDataAge(String) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setDatabaseInfo(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'databaseInfo' field.
setDatabaseInfo(Map<String, String>) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setDatabaseLookupLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setDatabaseLookupLatency(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setDatabaseLookupLatency(double) - Method in class com.linkedin.venice.listener.StatsHandler
 
setDatabaseSyncBytesInterval(long) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
Sets the value for databaseSyncBytesInterval.
setDataRecoveryComplete(boolean) - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
 
setDataRecoveryComplete(boolean) - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
setDataRecoveryCompleted(boolean) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setDataRecoveryConfig(DataRecoveryConfig) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'dataRecoveryConfig' field.
setDataRecoverySourceFabric(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Sets the value of the 'dataRecoverySourceFabric' field.
setDataRecoverySourceFabric(String) - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
 
setDataRecoverySourceFabric(String) - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
setDataRecoverySourceVersionNumber(int) - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
 
setDataRecoverySourceVersionNumber(int) - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
 
setDataRecoverySourceVersionNumber(int) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Sets the value of the 'dataRecoverySourceVersionNumber' field.
setDataRecoveryVersionConfig(DataRecoveryVersionConfig) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setDataRecoveryVersionConfig(DataRecoveryVersionConfig) - Method in interface com.linkedin.venice.meta.Version
 
setDataRecoveryVersionConfig(DataRecoveryVersionConfig) - Method in class com.linkedin.venice.meta.VersionImpl
 
setDataReplicationPolicy(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Sets the value of the 'dataReplicationPolicy' field.
setDataReplicationPolicy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Sets the value of the 'dataReplicationPolicy' field.
setDataReplicationPolicy(DataReplicationPolicy) - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
setDataReplicationPolicy(DataReplicationPolicy) - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
setDateTime(LocalDateTime) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
setDaVinciClientForMetaStore(DaVinciClient<StoreMetaKey, StoreMetaValue>) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setDaVinciPushStatusStoreEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setDaVinciPushStatusStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setDaVinciPushStatusStoreEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setDaVinciPushStatusStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setDaVinciPushStatusStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setDaVinciPushStatusStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setDaVinciPushStatusStoreEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'daVinciPushStatusStoreEnabled' field.
setDaVinciPushStatusStoreEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'daVinciPushStatusStoreEnabled' field.
setDebug(boolean) - Method in class com.linkedin.alpini.log.FastLog
 
setDebug(boolean) - Method in interface com.linkedin.alpini.log.FastLogMBean
 
setDebug(boolean) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setDebugInfo(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
Sets the value of the 'debugInfo' field.
setDebugInfo(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'debugInfo' field.
setDefaultTimeoutMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
setDeferredWrite(boolean) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setDeferredWrite(boolean) - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
setDeferredWrite(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'deferredWrite' field.
setDeferVersionSwap(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'deferVersionSwap' field.
setDefinition(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
Sets the value of the 'definition' field.
setDeflateDictionary(byte[], int) - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
setDeflateDictionary(byte[], int) - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
setDelegate(ClusterLeaderInitializationRoutine) - Method in class com.linkedin.venice.controller.init.DelegatingClusterLeaderInitializationRoutine
 
setDeletedElementsAndTimestamps(List<DELETED_ELEMENT_TYPE>, List<Long>) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
setDELETEDTS(Long) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Sets the value of the 'DELETED_TS' field.
setDeleting(boolean) - Method in class com.linkedin.venice.meta.StoreConfig
 
setDeleting(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Sets the value of the 'deleting' field.
setDerivedSchemaId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Sets the value of the 'derivedSchemaId' field.
setDerivedSchemaId(int) - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
setDerivedSchemaId(int) - Method in class com.linkedin.venice.controllerapi.SchemaResponse
 
setDescription(String) - Method in class com.linkedin.venice.status.StoreStatusMessage
 
setDeserializationExecutor(Executor) - Method in class com.linkedin.venice.client.store.ClientConfig
Provide an arbitrary executor to execute client requests in, rather than letting the client use its own internally-generated executor.
setDeserializationExecutor(Executor) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setDestClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
Sets the value of the 'destClusterName' field.
setDestClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
Sets the value of the 'destClusterName' field.
setDestFabric(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setDestVersionCompressor(VeniceCompressor) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
setDetail(ByteBuffer) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Sets the value of the 'detail' field.
setDetails(String) - Method in class com.linkedin.venice.controllerapi.NodeStatusResponse
 
setDictionary(byte[], int) - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
setDictSampleSize(int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setDisableDavinciPushStatusStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setDisableDavinciPushStatusStore(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'disableDavinciPushStatusStore' field.
setDisableMetaStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setDisableMetaStore(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'disableMetaStore' field.
setDisableStoreView() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setDiskUsage(DiskUsage) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setDispatchMinimumMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
setDotProductCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setDotProductCount(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setDotProductParam(List<Float>) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
Sets the value of the 'dotProductParam' field.
setDoUpdateSupersetSchemaID(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Sets the value of the 'doUpdateSupersetSchemaID' field.
setDualReadEnabled(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setDuplicateMsg(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setEarlyThrottleEnabled(boolean) - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
setElapsedTimeSinceLastPollInMs(long) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
setElementsToAddToListField(String, List<?>) - Method in interface com.linkedin.venice.writer.update.UpdateBuilder
Set elements to be added to a List/Array field.
setElementsToAddToListField(String, List<?>) - Method in class com.linkedin.venice.writer.update.UpdateBuilderImpl
 
setElementsToRemoveFromListField(String, List<?>) - Method in interface com.linkedin.venice.writer.update.UpdateBuilder
Set elements to be removed from a List/Array field.
setElementsToRemoveFromListField(String, List<?>) - Method in class com.linkedin.venice.writer.update.UpdateBuilderImpl
 
setEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Sets the value of the 'enabled' field.
setEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Sets the value of the 'enabled' field.
setEnableReads(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'enableReads' field.
setEnableReads(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setEnableReads(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setEnableReads(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setEnableReads(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setEnableReads(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setEnableReads(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'enableReads' field.
setEnableReads(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'enableReads' field.
setEnableSSL(boolean) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setEnableStoreReads(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setEnableStoreWrites(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setEnableWrites(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'enableWrites' field.
setEnableWrites(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setEnableWrites(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setEnableWrites(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setEnableWrites(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setEnableWrites(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setEnableWrites(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'enableWrites' field.
setEnableWrites(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'enableWrites' field.
setEndOfPush(boolean) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'endOfPush' field.
setEndOfPushTimestamp(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setEndOfPushTimestamp(long) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'endOfPushTimestamp' field.
setEntriesToAddToMapField(String, Map<String, ?>) - Method in interface com.linkedin.venice.writer.update.UpdateBuilder
Set k-v entries to be added to a Map field.
setEntriesToAddToMapField(String, Map<String, ?>) - Method in class com.linkedin.venice.writer.update.UpdateBuilderImpl
 
setError() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setError(boolean) - Method in class com.linkedin.davinci.listener.response.AdminResponse
 
setError(boolean) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setError(boolean) - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
 
setError(boolean) - Method in class com.linkedin.davinci.listener.response.TopicPartitionIngestionContextResponse
 
setError(boolean) - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
setError(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
Sets the value of the 'error' field.
setError(String) - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
setError(String) - Method in class com.linkedin.venice.datarecovery.Command.Result
 
setError(String, Throwable) - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
setError(Throwable) - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
setErrorCode(int) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 errorCode = 6;
setErrorMessage(String) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setErrorMessage(String) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
string errorMessage = 7;
setErrorMessageBytes(ByteString) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
string errorMessage = 7;
setErrorReported(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'errorReported' field.
setErrorType(ErrorType) - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
setEstimatedRecoveryTimeInSeconds(Long) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
setEtlConfig(StoreETLConfig) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'etlConfig' field.
setEtledProxyUserAccount(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setEtledUserProxyAccount(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
Sets the value of the 'etledUserProxyAccount' field.
setEtledUserProxyAccount(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
Sets the value of the 'etledUserProxyAccount' field.
setEtledUserProxyAccount(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Sets the value of the 'etledUserProxyAccount' field.
setEtledUserProxyAccount(String) - Method in interface com.linkedin.venice.meta.ETLStoreConfig
 
setEtledUserProxyAccount(String) - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
setEtlStoreConfig(ETLStoreConfig) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setEtlStoreConfig(ETLStoreConfig) - Method in interface com.linkedin.venice.meta.Store
 
setEtlStoreConfig(ETLStoreConfig) - Method in class com.linkedin.venice.meta.StoreInfo
 
setEtlStoreConfig(ETLStoreConfig) - Method in class com.linkedin.venice.meta.SystemStore
 
setEtlStoreConfig(ETLStoreConfig) - Method in class com.linkedin.venice.meta.ZKStore
 
setEtlStoreConfig(ETLStoreConfig) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'etlStoreConfig' field.
setETLStoreConfig(ETLStoreConfigRecord) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'ETLStoreConfig' field.
setExceedQuota(boolean) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
setExceedQuota(boolean) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
setException(IOException) - Method in class com.linkedin.alpini.io.CompressOutputStream
 
setException(Throwable) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
setExceptionThrown(boolean) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'exceptionThrown' field.
setExecuteExistingDelayedTasksAfterShutdownPolicy(boolean) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Sets the policy on whether to execute existing delayed tasks even when this executor has been shutdown.
setExecution(AdminCommandExecution) - Method in class com.linkedin.venice.controllerapi.routes.AdminCommandExecutionResponse
 
setExecutionId(long) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
setExecutionId(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
Sets the value of the 'executionId' field.
setExecutionId(long) - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
setExecutionId(long) - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
 
setExecutionId(long) - Method in class com.linkedin.venice.controllerapi.TrackableControllerResponse
 
setExecutionStatus(ExecutionStatus) - Method in class com.linkedin.venice.routerapi.PushStatusResponse
 
setExecutor(Executor) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setExitCode(int) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
 
setExitMode(SamzaExitMode) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
setExpectedRouterCount(int) - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
setExternalSupersetSchemaGenerator(SupersetSchemaGenerator) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setExtraCommandArgs(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setExtraDetails(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setExtraInfo(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setExtraInfoUpdateTimestamp(Map<String, Long>) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setFabricToExecutionStatusMap(ConcurrentMap<String, AdminCommandExecutionStatus>) - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
setFailure(Throwable) - Method in interface com.linkedin.alpini.base.concurrency.AsyncPromise
Marks this future as a failure and notifies all listeners.
setFailure(Throwable) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
setFailure(Throwable) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Marks this future as a failure and notifies all listeners.
setFailure(Throwable) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Marks this future as a failure and notifies all listeners.
setFailure(Throwable) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
setFailure(Throwable) - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
setFailure(Throwable) - Method in class io.netty.bootstrap.PendingConnectPromise
 
setFailureDetails(CharSequence) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'failureDetails' field.
setFairAllocationRatio(String) - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
setField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
setField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
setField(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
Sets the value of the 'field' field.
setField(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.Count
Sets the value of the 'field' field.
setField(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
Sets the value of the 'field' field.
setField(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
Sets the value of the 'field' field.
setFieldSchema(String, Schema) - Method in class com.linkedin.venice.utils.PushInputSchemaBuilder
 
setFieldsPerPopulationMethod(int) - Static method in class com.linkedin.avro.fastserde.FastDeserializerGeneratorAccessor
 
setFinalSegment(boolean) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
Sets the value of the 'finalSegment' field.
setFirstPartLatency(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setFlushIntervalMs(long) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setForceClusterDiscoveryAtStartTime(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setFrameStream(AttributeMap, Http2FrameStream) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
 
setFutureStats(int, STATS) - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
setFutureVersion(int) - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
setFutureVersion(int) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Result
 
setFutureVersionETLEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
Sets the value of the 'futureVersionETLEnabled' field.
setFutureVersionETLEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setFutureVersionETLEnabled(boolean) - Method in interface com.linkedin.venice.meta.ETLStoreConfig
 
setFutureVersionETLEnabled(boolean) - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
setFutureVersionETLEnabled(boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
Sets the value of the 'futureVersionETLEnabled' field.
setFutureVersionETLEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Sets the value of the 'futureVersionETLEnabled' field.
setGenericThinClient(AvroGenericStoreClient<K, V>) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setGlobalShutdownDelayMillis(long) - Static method in class com.linkedin.alpini.base.registry.ResourceRegistry
Set a delay for global shutdown.
setGrpcClientConfig(GrpcClientConfig) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setGrpcStatsContext(ServerStatsContext) - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setHadamardProductCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setHadamardProductCount(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setHadamardProductParam(List<Float>) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
Sets the value of the 'hadamardProductParam' field.
setHadoopJobClientProvider(HadoopJobClientProvider) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
setHealthCheckIntervalMillis(long) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
setHealthCheckIntervalMillis(LongSupplier) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
setHealthyRegions(Map<String, StoreInfo>) - Method in class com.linkedin.venice.meta.StoreDataAudit
 
setHeartbeatMonitoringService(HeartbeatMonitoringService) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setHeartbeatTimestamp(long) - Method in class com.linkedin.venice.controllerapi.SystemStoreHeartbeatResponse
 
setHelixGroupId(int) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setHelixGroupInfo(Map<CharSequence, Integer>) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setHelixGroupInfo(Map<CharSequence, Integer>) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'helixGroupInfo' field.
setHostAsHealthy(Instance) - Method in class com.linkedin.venice.router.api.VeniceHostHealth
If the host is marked as unhealthy before, remove it from the unhealthy host set and log this status change.
setHostAsUnhealthy(Instance) - Method in class com.linkedin.venice.router.api.VeniceHostHealth
Mark that something is wrong with an entire host and it should not be used for queries.
setHostLevelIngestionStats(AggHostLevelIngestionStats) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setHostname(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setHostName(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Sets the value of the 'hostName' field.
setHostnameVerifier(HostnameVerifier) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Assigns HostnameVerifier instance.
setHttp1(boolean) - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
setHttp1MaxConnectionsPerRoute(int) - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
setHttp1MaxConnectionsTotal(int) - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
setHttp2PingSendHandlerFunction(Function<Channel, Http2PingSendHandler>) - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolFactory
 
setHttp2PipelineInitializer(Http2PipelineInitializer.BuilderSupplier) - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
 
setHttpClient5Http2Enabled(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setHttpClientTransport(HttpClientTransport) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionRequestClient
 
setHttpClientTransport(HttpClientTransport) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
setHybrid(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'hybrid' field.
setHybrid(boolean) - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
setHybrid(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'hybrid' field.
setHybridBufferReplayPolicy(BufferReplayPolicy) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setHybridConfig(StoreHybridConfig) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'hybridConfig' field.
setHybridConfig(StoreHybridConfig) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'hybridConfig' field.
setHybridDataReplicationPolicy(DataReplicationPolicy) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setHybridOffsetLagThreshold(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setHybridRewindSeconds(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setHybridStoreConfig(HybridStoreConfigRecord) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'hybridStoreConfig' field.
setHybridStoreConfig(HybridStoreConfig) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setHybridStoreConfig(HybridStoreConfig) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setHybridStoreConfig(HybridStoreConfig) - Method in interface com.linkedin.venice.meta.Store
 
setHybridStoreConfig(HybridStoreConfig) - Method in class com.linkedin.venice.meta.StoreInfo
 
setHybridStoreConfig(HybridStoreConfig) - Method in class com.linkedin.venice.meta.SystemStore
 
setHybridStoreConfig(HybridStoreConfig) - Method in interface com.linkedin.venice.meta.Version
 
setHybridStoreConfig(HybridStoreConfig) - Method in class com.linkedin.venice.meta.VersionImpl
 
setHybridStoreConfig(HybridStoreConfig) - Method in class com.linkedin.venice.meta.ZKStore
 
setHybridStoreConfig(HybridStoreConfig) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'hybridStoreConfig' field.
setHybridStoreDiskQuotaEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'hybridStoreDiskQuotaEnabled' field.
setHybridStoreDiskQuotaEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setHybridStoreDiskQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setHybridStoreDiskQuotaEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setHybridStoreDiskQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setHybridStoreDiskQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setHybridStoreDiskQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setHybridStoreDiskQuotaEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'hybridStoreDiskQuotaEnabled' field.
setHybridStoreDiskQuotaEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'hybridStoreDiskQuotaEnabled' field.
setHybridStoreOverheadBypass(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'hybridStoreOverheadBypass' field.
setHybridStoreOverheadBypass(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setHybridStoreOverheadBypass(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setHybridTimeLagThreshold(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setIcProvider(ICProvider) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setIcProvider(ICProvider) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setId(int) - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
Sets the value of the 'id' field.
setId(int) - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
setId(int) - Method in class com.linkedin.venice.controllerapi.SchemaResponse
 
setIdentityParser(Function<X509Certificate, String>) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'incrementalPushEnabled' field.
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setIncrementalPushEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setIncrementalPushEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'incrementalPushEnabled' field.
setIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'incrementalPushEnabled' field.
setIncrementalPushEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'incrementalPushEnabled' field.
setIncrementalPushInfo(IncrementalPush) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'incrementalPushInfo' field.
setIncrementalPushPolicy(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'incrementalPushPolicy' field.
setIncrementalPushPolicy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'incrementalPushPolicy' field.
setIncrementalPushPolicy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'incrementalPushPolicy' field.
setIncrementalPushPolicyToApply(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Sets the value of the 'incrementalPushPolicyToApply' field.
setIncrementalPushPolicyToFilter(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Sets the value of the 'incrementalPushPolicyToFilter' field.
setIncrementalPushVersion(String) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setIncrementalPushVersion(String) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
setIncrementalPushVersion(String) - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
 
setIncrementalPushVersions(Set<String>) - Method in class com.linkedin.venice.controllerapi.IncrementalPushVersionsResponse
 
setIngestionTask(StoreIngestionTask) - Method in class com.linkedin.davinci.stats.IngestionStats
 
setIngestionTask(String, StoreIngestionTask) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
setIngestionTaskPushTimeoutGauge(int) - Method in class com.linkedin.davinci.stats.IngestionStats
 
setIngestionTaskPushTimeoutGauge(String, int) - Method in class com.linkedin.davinci.stats.AggVersionedIngestionStats
 
setInputConf(SparkSession, DataFrameReader, String, String) - Method in class com.linkedin.venice.hadoop.spark.datawriter.jobs.AbstractDataWriterSparkJob
 
setInputDataInfoProvider(InputDataInfoProvider) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
setInputFileDataSize(long) - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
Sets the value of the 'inputFileDataSize' field.
setInputFileDataSizeInBytes(long) - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
 
setInstanceId(String) - Method in class com.linkedin.venice.meta.ReplicaDetail
 
setInstanceId(String) - Method in class com.linkedin.venice.meta.UncompletedReplica
 
setInstances(Map<CharSequence, Integer>) - Method in class com.linkedin.venice.pushstatus.PushStatusValue
Sets the value of the 'instances' field.
setInstancesStatusMap(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.MultiNodesStatusResponse
 
setInt(CharSequence, int) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
setInterceptor(ServerInterceptor) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setInterceptors(List<? extends ServerInterceptor>) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setInterval(int) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient.DataRecoveryParams
 
setInterval(int) - Method in class com.linkedin.venice.datarecovery.DataRecoveryMonitor
 
setInUseValueSchemaIds(Set<Integer>) - Method in class com.linkedin.venice.controllerapi.SchemaUsageResponse
 
setIoThreadCount(int) - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
setIsBatchRequest(boolean) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isBatchRequest = 9;
setIsChunk(boolean) - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
Sets the value of the 'isChunk' field.
setIsDataRecoveryComplete(boolean) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
Sets the value of the 'isDataRecoveryComplete' field.
setIsDaVinciClient(boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setIsIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'isIncrementalPushEnabled' field.
setIsLastVersionSwapMessageFromRealTimeTopic(boolean) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Sets the value of the 'isLastVersionSwapMessageFromRealTimeTopic' field.
setIsLatchReleased(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'isLatchReleased' field.
setIsMetadataConnWarmupEnabled(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setIsMigrating(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'isMigrating' field.
setIsNoopThrottlerEnabled(boolean) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
 
setIsNoopThrottlerEnabled(boolean) - Method in interface com.linkedin.venice.router.throttle.RouterThrottler
 
setIsolated(boolean) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
setIsolatedIngestionServiceProcess(Process) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
setIsPositive(boolean) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'isPositive' field.
setIsReadyLatch(CountDownLatch) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
setIsRegistered(boolean) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'isRegistered' field.
setIsRepush(boolean) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Sets the value of the 'isRepush' field.
setIsReqRedirectionAllowedForQuery(BooleanSupplier) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
setIsRetryRequest(boolean) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isRetryRequest = 8;
setIsStreamingRequest(boolean) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
bool isStreamingRequest = 7;
setIsStreamingResponse(boolean) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
bool isStreamingResponse = 5;
setJobClientWrapper(JobClientWrapper) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
setJobClientWrapper(JobClientWrapper) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
setJobDurationInMs(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'jobDurationInMs' field.
setKafkaBootstrapServers(String) - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
setKafkaBootstrapServers(String) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setKafkaBrokerUrl(String) - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
setKafkaBrokerUrl(String) - Method in class com.linkedin.venice.meta.StoreInfo
 
setKafkaInputBroker(String) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setKafkaSaslConfig(String) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setKafkaSaslMechanism(String) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setKafkaSecurityProtocol(String) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setKafkaSourceRegion(String) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setKafkaTopic(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
Sets the value of the 'kafkaTopic' field.
setKafkaTopic(String) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setKafKaTopic(String) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Result
 
setKeepAlive(HR, boolean) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
setKeepAlive(FullHttpResponse, boolean) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
setKey(KafkaKey) - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
setKey(ByteBuffer) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Sets the value of the 'key' field.
setKey(ByteBuffer) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Sets the value of the 'key' field.
setKey(ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
Sets the value of the 'key' field.
setKeyBytes(byte[]) - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
setKeyBytes(ByteString) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for batch get
setKeyBytes(ByteBuffer) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Sets the value of the 'keyBytes' field.
setKeyBytes(ByteBuffer) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Sets the value of the 'keyBytes' field.
setKeyIndex(int) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Sets the value of the 'keyIndex' field.
setKeyIndex(int) - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
Sets the value of the 'keyIndex' field.
setKeyIndex(int) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Sets the value of the 'keyIndex' field.
setKeyIndex(int) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Sets the value of the 'keyIndex' field.
setKeyManagerAlgorithm(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setKeyPassphrase(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setKeySchema(SchemaMeta) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Sets the value of the 'keySchema' field.
setKeySchema(SchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
 
setKeySchema(String) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setKeySchema(Map<CharSequence, CharSequence>) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setKeySchema(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'keySchema' field.
setKeySchema(Schema) - Method in class com.linkedin.venice.utils.PushInputSchemaBuilder
 
setKeySchemaMap(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
Sets the value of the 'keySchemaMap' field.
setKeySchemaMap(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
Sets the value of the 'keySchemaMap' field.
setKeySerializer(VeniceKafkaSerializer) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setKeySizeList(IntList) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setKeySizeList(IntList) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setKeySizeList(IntList) - Method in class com.linkedin.venice.listener.StatsHandler
 
setKeyStoreData(String) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setKeyStoreData(String) - Method in class com.linkedin.venice.security.SSLConfig
 
setKeyStoreFilePath(String) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setKeyStoreFilePath(String) - Method in class com.linkedin.venice.security.SSLConfig
 
setKeysToRemoveFromMapField(String, List<String>) - Method in interface com.linkedin.venice.writer.update.UpdateBuilder
Set keys to be added to a Map field.
setKeysToRemoveFromMapField(String, List<String>) - Method in class com.linkedin.venice.writer.update.UpdateBuilderImpl
 
setKeyStorePassword(String) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setKeyStorePassword(String) - Method in class com.linkedin.venice.security.SSLConfig
 
setKeyStorePassword(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setKeyStorePath(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setKeyStoreType(String) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setKeyStoreType(String) - Method in class com.linkedin.venice.security.SSLConfig
 
setKeyStoreType(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setKeyString(String) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for single get
setKeyStringBytes(ByteString) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
used for single get
setKeyStrings(List<CharSequence>) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
Sets the value of the 'keyStrings' field.
setKeyStrings(List<CharSequence>) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
Sets the value of the 'keyStrings' field.
setKeyStrings(List<Object>) - Method in class com.linkedin.venice.pushstatus.PushStatusKey
Sets the value of the 'keyStrings' field.
setKeysWithChunkIdSuffix(List<ByteBuffer>) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
Sets the value of the 'keysWithChunkIdSuffix' field.
setLagCaughtUp(boolean) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'lagCaughtUp' field.
setLargeBatchRequestSplitThreshold(int) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
Sets the value of the 'largestUsedVersionNumber' field.
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setLargestUsedVersionNumber(int) - Method in interface com.linkedin.venice.meta.Store
 
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setLargestUsedVersionNumber(int) - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'largestUsedVersionNumber' field.
setLargestUsedVersionNumber(int) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Sets the value of the 'largestUsedVersionNumber' field.
setLargestUsedVersionNumber(Integer) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'largestUsedVersionNumber' field.
setLargestUsedVersionNumber(Integer) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'largestUsedVersionNumber' field.
setLastConsumerException(Exception) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
setLastLeaderCompleteStateUpdateInMs(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLastLeaderPersistFuture(Future<Void>) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLastQueuedRecordPersistedFuture(CompletableFuture<Void>) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLastRecordProducerTimestamp(long) - Method in class com.linkedin.venice.kafka.validation.Segment
 
setLastRecordTimestamp(long) - Method in class com.linkedin.venice.kafka.validation.Segment
 
setLastStoreIngestionException(Exception) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
setLastSucceedExecutionId(long) - Method in class com.linkedin.venice.LastSucceedExecutionIdResponse
 
setLastSuccessfulOffset(long) - Method in class com.linkedin.venice.kafka.validation.Segment
 
setLastUpdate(long) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'lastUpdate' field.
setLastVTProduceCallFuture(CompletableFuture<Void>) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLatestCreatedVersion(int) - Method in class com.linkedin.venice.meta.StoreDataAudit
 
setLatestFailedPush(String) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setLatestMessageConsumedTimestampInMs(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLatestMessageConsumptionTimestampInMs(long) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'latestMessageConsumptionTimestampInMs' field.
setLatestPolledMessageTimestampInMs(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLatestProducerProcessingTimeInMs(long) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setLatestSuccessfulPushVersion(int) - Method in class com.linkedin.venice.meta.StoreDataAudit
 
setLatestSupersetSchemaId(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setLatestSuperSetValueSchemaId(int) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setLatestSuperSetValueSchemaId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'latestSuperSetValueSchemaId' field.
setLatestSuperSetValueSchemaId(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setLatestSuperSetValueSchemaId(int) - Method in interface com.linkedin.venice.meta.Store
 
setLatestSuperSetValueSchemaId(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setLatestSuperSetValueSchemaId(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setLatestSuperSetValueSchemaId(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setLatestSuperSetValueSchemaId(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'latestSuperSetValueSchemaId' field.
setLatestSuperSetValueSchemaId(Integer) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'latestSuperSetValueSchemaId' field.
setLatestSuperSetValueSchemaId(Integer) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'latestSuperSetValueSchemaId' field.
setLatestVersionPromoteToCurrentTimestamp(long) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setLatestVersionPromoteToCurrentTimestamp(long) - Method in interface com.linkedin.venice.meta.Store
 
setLatestVersionPromoteToCurrentTimestamp(long) - Method in class com.linkedin.venice.meta.SystemStore
 
setLatestVersionPromoteToCurrentTimestamp(long) - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
setLatestVersionPromoteToCurrentTimestamp(long) - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
setLatestVersionPromoteToCurrentTimestamp(long) - Method in class com.linkedin.venice.meta.ZKStore
 
setLatestVersionPromoteToCurrentTimestamp(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'latestVersionPromoteToCurrentTimestamp' field.
setLatestVersionPromoteToCurrentTimestamp(long) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Sets the value of the 'latestVersionPromoteToCurrentTimestamp' field.
setLeaderCompleteState(LeaderCompleteState) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLeaderFollowerModelEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'leaderFollowerModelEnabled' field.
setLeaderFollowerModelEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
Deprecated.
setLeaderFollowerModelEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setLeaderFollowerModelEnabled(boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'leaderFollowerModelEnabled' field.
setLeaderFollowerModelEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
Deprecated.
setLeaderFollowerModelEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'leaderFollowerModelEnabled' field.
setLeaderFollowerModelEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'leaderFollowerModelEnabled' field.
setLeaderFollowerModelEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'leaderFollowerModelEnabled' field.
setLeaderFollowerNotifiersQueue(Queue<VeniceNotifier>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setLeaderFollowerState(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'leaderFollowerState' field.
setLeaderFollowerState(LeaderFollowerStateType) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLeaderGUID(GUID) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLeaderGUID(GUID) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'leaderGUID' field.
setLeaderGUID(GUID) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setLeaderHostId(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'leaderHostId' field.
setLeaderHostId(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setLeaderHostId(String) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setLeaderMetadataFooter(LeaderMetadata) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Sets the value of the 'leaderMetadataFooter' field.
setLeaderOffset(long) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'leaderOffset' field.
setLeaderProducerFailure(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setLeaderState(CharSequence) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'leaderState' field.
setLeaderTopic(PubSubTopic) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setLeaderTopic(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'leaderTopic' field.
setLeaderUpstreamOffset(String, long) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setLevel(Level) - Method in class com.linkedin.venice.utils.ForkedJavaProcess.LogInfo
 
setLevel(Logger, Level) - Static method in class com.linkedin.alpini.consts.Level
This uses reflection to call the innards of log4j2 without requiring the module to pull in more than the log4j2Api library.
setLiveInstanceInfoProvider(LiveInstanceInfoProvider) - Method in class com.linkedin.venice.helix.SafeHelixManager
 
setLocalD2ZkHosts(String) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setLocalHighWatermarks(List<Long>) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Sets the value of the 'localHighWatermarks' field.
setLog(String) - Method in class com.linkedin.venice.utils.ForkedJavaProcess.LogInfo
 
setLogCompacted(boolean) - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
setLogicalTimestamp(long) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Sets the value of the 'logicalTimestamp' field.
setLogInboundRst(boolean) - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
 
setLongTailMinimumMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
 
setLongTailRetryBudgetEnforcementWindowInMs(long) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setLongTailRetryEnabledForBatchGet(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setLongTailRetryEnabledForCompute(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setLongTailRetryEnabledForSingleGet(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setLongTailRetryThresholdForBatchGetInMicroSeconds(int) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setLongTailRetryThresholdForComputeInMicroSeconds(int) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setLongTailRetryThresholdForSingleGetInMicroSeconds(int) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setLongTailRetryThresholdMs(int) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setLowWatermark(long) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setLowWatermark(long) - Method in interface com.linkedin.venice.meta.Store
 
setLowWatermark(long) - Method in class com.linkedin.venice.meta.StoreInfo
 
setLowWatermark(long) - Method in class com.linkedin.venice.meta.SystemStore
 
setLowWatermark(long) - Method in class com.linkedin.venice.meta.ZKStore
 
setLowWatermark(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'lowWatermark' field.
setManaged(boolean) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
setManaged(boolean) - Method in class com.linkedin.davinci.config.StoreBackendConfig
 
setManaged(boolean) - Method in class com.linkedin.davinci.StoreBackend
 
setManifest(ChunkedValueManifest) - Method in class com.linkedin.davinci.storage.chunking.ChunkedValueManifestContainer
 
setMapper(ObjectMapper) - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor.HybridQuotaMonitorTask
 
setMaxAdminConsumptionOffsetLag(long) - Method in class com.linkedin.venice.controller.stats.AdminConsumptionStats
 
setMaxCapacityProtectionEnabled(boolean) - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
setMaxCompactionLagSeconds(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'maxCompactionLagSeconds' field.
setMaxCompactionLagSeconds(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setMaxCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setMaxCompactionLagSeconds(long) - Method in interface com.linkedin.venice.meta.Store
 
setMaxCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.StoreInfo
 
setMaxCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.SystemStore
 
setMaxCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.ZKStore
 
setMaxCompactionLagSeconds(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'maxCompactionLagSeconds' field.
setMaxConcurrentStreams(long) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
setMaxConnections(IntSupplier) - Method in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
setMaxConnectionsPerRoute(int) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setMaxConnectionsTotal(int) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setMaxCumulationBufferComponents(int) - Method in class io.netty.handler.codec.EspressoMessageAggregator
Sets the maximum number of components in the cumulation buffer.
setMaxLogCompactionLagMs(Optional<Long>) - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
The maximum time a message will remain ineligible for compaction in the log.
setMaxNumberUnflushedRecords(int) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setMaxPerPartitionCacheSize(Long) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
setMaxQueueLength(int) - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
setMaxReuseStreamChannelsLimit(int) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
setMemoryLimit(long) - Method in class com.linkedin.davinci.stats.RocksDBMemoryStats
 
setMessage(CharSequence) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'message' field.
setMessage(String) - Method in class com.linkedin.davinci.listener.response.AdminResponse
 
setMessage(String) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setMessage(String) - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
 
setMessage(String) - Method in class com.linkedin.davinci.listener.response.TopicPartitionIngestionContextResponse
 
setMessage(String) - Method in class com.linkedin.venice.datarecovery.Command.Result
 
setMessage(String) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
 
setMessageSequenceNumber(int) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Sets the value of the 'messageSequenceNumber' field.
setMessageSequenceNumber(int) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'messageSequenceNumber' field.
setMessageSequenceNumber(int) - Method in class com.linkedin.venice.storage.protocol.ChunkId
Sets the value of the 'messageSequenceNumber' field.
setMessageTimestamp(long) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Sets the value of the 'messageTimestamp' field.
setMessageTimestamp(long) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'messageTimestamp' field.
setMessageType(int) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Sets the value of the 'messageType' field.
setMessageType(int) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
Sets the value of the 'messageType' field.
setMessageType(int) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
Sets the value of the 'messageType' field.
setMessageType(int) - Method in class com.linkedin.venice.pushstatus.PushStatusKey
Sets the value of the 'messageType' field.
setMessageUnion(Object) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
Sets the value of the 'messageUnion' field.
setMetadata(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Sets the value of the 'metadata' field.
setMetadataConnWarmupTimeoutInSeconds(long) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setMetadataRefreshIntervalInSeconds(long) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setMetadataRepository(ReadOnlyStoreRepository) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setMetadataRequest(boolean) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setMetadataRequest(boolean) - Method in class com.linkedin.venice.listener.StatsHandler
 
setMetadataSchema(SchemaMeta) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Sets the value of the 'metadataSchema' field.
setMetadataType(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
Sets the value of the 'metadataType' field.
setMetadataType(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
Sets the value of the 'metadataType' field.
setMetadataUnion(Object) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
Sets the value of the 'metadataUnion' field.
setMetadataUpdateType(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Sets the value of the 'metadataUpdateType' field.
setMetaStoreWriter(MetaStoreWriter) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setMethod(HttpMethod) - Method in class com.linkedin.alpini.netty4.http2.Http1FullRequest
setMethod(HttpMethod) - Method in class com.linkedin.alpini.netty4.http2.Http1Request
setMethod(HttpMethod) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
setMethod(HttpMethod) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
setMethod(String) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string method = 10;
setMethodBytes(ByteString) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string method = 10;
setMetric(MetricNames, TimeValue) - Method in class com.linkedin.alpini.base.misc.Metrics
 
setMetric(Metrics, MetricNames, Supplier<TimeValue>) - Static method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
setMetricsRepository(MetricsRepository) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setMetricsRepository(MetricsRepository) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setMetricsRepository(MetricsRepository) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setMetricsRepository(MetricsRepository) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setMetricsRepository(MetricsRepository) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setMetricsRepository(MetricsRepository) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setMigrating(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setMigrating(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setMigrating(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setMigrating(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setMigrating(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setMigrating(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'migrating' field.
setMigrating(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'migrating' field.
setMigrationDestCluster(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Sets the value of the 'migrationDestCluster' field.
setMigrationDestCluster(String) - Method in class com.linkedin.venice.meta.StoreConfig
 
setMigrationDuplicateStore(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'migrationDuplicateStore' field.
setMigrationDuplicateStore(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setMigrationDuplicateStore(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setMigrationDuplicateStore(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setMigrationDuplicateStore(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setMigrationDuplicateStore(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setMigrationDuplicateStore(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setMigrationDuplicateStore(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'migrationDuplicateStore' field.
setMigrationPushStrategy(Admin) - Method in class com.linkedin.venice.controller.server.MigrationRoutes
 
setMigrationPushStrategy(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
setMigrationSrcCluster(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Sets the value of the 'migrationSrcCluster' field.
setMigrationSrcCluster(String) - Method in class com.linkedin.venice.meta.StoreConfig
 
setMinCompactionLagSeconds(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'minCompactionLagSeconds' field.
setMinCompactionLagSeconds(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setMinCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setMinCompactionLagSeconds(long) - Method in interface com.linkedin.venice.meta.Store
 
setMinCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.StoreInfo
 
setMinCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.SystemStore
 
setMinCompactionLagSeconds(long) - Method in class com.linkedin.venice.meta.ZKStore
 
setMinCompactionLagSeconds(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'minCompactionLagSeconds' field.
setMinConnections(int) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
setMinConnections(int) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
setMinConnections(int) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
setMinConnections(IntSupplier) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
setMinConnections(IntSupplier) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolImpl
 
setMinConnections(IntSupplier) - Method in class com.linkedin.alpini.netty4.pool.FixedFastChannelPoolImpl
 
setMinInSyncReplicas(Optional<Integer>) - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
setMinLogCompactionLagMs(Long) - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
setMisroutedStoreVersion(boolean) - Method in class com.linkedin.venice.listener.response.HttpShortcutResponse
 
setMisroutedStoreVersion(boolean) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setMisroutedStoreVersionRequest(boolean) - Method in class com.linkedin.venice.listener.StatsHandler
 
setMissingMsg(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setMockInMemoryAdminAdapter(MockInMemoryAdminAdapter) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
setMode(NettyUtils.Mode) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
setMode(String) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
setMoreThanOneHttp2Connection(boolean) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
setMsgRate(double) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
setMultiChunkLargeValueCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setMultiChunkLargeValueCount(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setMultiGetEnvelopeIterableImpl(AvroGenericDeserializer.IterableImpl) - Method in class com.linkedin.venice.client.store.ClientConfig
Deprecated.
setName(CharSequence) - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
Sets the value of the 'name' field.
setName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Sets the value of the 'name' field.
setName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
Sets the value of the 'name' field.
setName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Sets the value of the 'name' field.
setName(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'name' field.
setName(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'name' field.
setName(String) - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
setName(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
setName(String) - Method in class com.linkedin.venice.meta.StoreInfo
 
setName(String) - Method in class com.linkedin.venice.persona.Persona
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'nativeReplicationEnabled' field.
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setNativeReplicationEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'nativeReplicationEnabled' field.
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'nativeReplicationEnabled' field.
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setNativeReplicationEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'nativeReplicationEnabled' field.
setNativeReplicationEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'nativeReplicationEnabled' field.
setNativeReplicationSourceFabric(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'nativeReplicationSourceFabric' field.
setNativeReplicationSourceFabric(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'nativeReplicationSourceFabric' field.
setNativeReplicationSourceFabric(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'nativeReplicationSourceFabric' field.
setNativeReplicationSourceFabric(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setNativeReplicationSourceFabric(String) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setNativeReplicationSourceFabric(String) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setNativeReplicationSourceFabric(String) - Method in interface com.linkedin.venice.meta.Store
 
setNativeReplicationSourceFabric(String) - Method in class com.linkedin.venice.meta.StoreInfo
 
setNativeReplicationSourceFabric(String) - Method in class com.linkedin.venice.meta.SystemStore
 
setNativeReplicationSourceFabric(String) - Method in interface com.linkedin.venice.meta.Version
 
setNativeReplicationSourceFabric(String) - Method in class com.linkedin.venice.meta.VersionImpl
 
setNativeReplicationSourceFabric(String) - Method in class com.linkedin.venice.meta.ZKStore
 
setNativeReplicationSourceRegion(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Sets the value of the 'nativeReplicationSourceRegion' field.
setNettyServerToGrpcAddressMap(Map<String, String>) - Method in class com.linkedin.venice.fastclient.GrpcClientConfig.Builder
 
setNewFieldValue(String, Object) - Method in interface com.linkedin.venice.writer.update.UpdateBuilder
Set a new value to a field.
setNewFieldValue(String, Object) - Method in class com.linkedin.venice.writer.update.UpdateBuilderImpl
 
setNewRequest() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setNewSegment(boolean) - Method in class com.linkedin.venice.kafka.validation.Segment
 
setNewServingVersionTopic(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Sets the value of the 'newServingVersionTopic' field.
setNodes(String[]) - Method in class com.linkedin.venice.controllerapi.MultiNodeResponse
 
setNodeState(NodeReplicasReadinessState) - Method in class com.linkedin.venice.controllerapi.NodeReplicasReadinessResponse
 
setNonInteractive(boolean) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient.DataRecoveryParams
 
setNumber(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setNumber(int) - Method in interface com.linkedin.venice.meta.Version
 
setNumber(int) - Method in class com.linkedin.venice.meta.VersionImpl
 
setNumber(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'number' field.
setNumberOfPartitions(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'numberOfPartitions' field.
setNumThreads(int) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setNumVersionsToPreserve(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'numVersionsToPreserve' field.
setNumVersionsToPreserve(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setNumVersionsToPreserve(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setNumVersionsToPreserve(int) - Method in interface com.linkedin.venice.meta.Store
 
setNumVersionsToPreserve(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setNumVersionsToPreserve(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setNumVersionsToPreserve(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setNumVersionsToPreserve(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'numVersionsToPreserve' field.
setNumVersionsToPreserve(Integer) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'numVersionsToPreserve' field.
setOf(Collection<T>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
setOf(T) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
setOf(T...) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
setOf(T...) - Static method in class com.linkedin.venice.utils.Utils
 
setOfflinePushStrategy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'offlinePushStrategy' field.
setOffLinePushStrategy(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'offLinePushStrategy' field.
setOffset(long) - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
 
setOffset(long) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Sets the value of the 'offset' field.
setOffset(long) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
Sets the value of the 'offset' field.
setOffset(long) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Sets the value of the 'offset' field.
setOffset(long) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'offset' field.
setOffset(long) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'offset' field.
setOffset(long) - Method in class com.linkedin.venice.status.StoreStatusMessage
 
setOffset(long) - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
setOffsetLag(long) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
setOffsetLag(long) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'offsetLag' field.
setOffsetLag(long) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setOffsetLagThresholdToGoOnline(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Sets the value of the 'offsetLagThresholdToGoOnline' field.
setOffsetLagThresholdToGoOnline(long) - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
setOffsetLagThresholdToGoOnline(long) - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
setOffsetLagThresholdToGoOnline(long) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
Sets the value of the 'offsetLagThresholdToGoOnline' field.
setOffsetLagThresholdToGoOnline(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Sets the value of the 'offsetLagThresholdToGoOnline' field.
setOffsetRecord(Object) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'offsetRecord' field.
setOffsetRecordArray(List<ByteBuffer>) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'offsetRecordArray' field.
setOffsetToSkip(String, long, boolean) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
Skip admin message with specified offset for the given cluster.
setOldServingVersionTopic(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
Sets the value of the 'oldServingVersionTopic' field.
setOnCompletionFunction(Runnable) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveProducerCallback
 
setOnDemandDeserializerNumberOfRecordsPerThread(int) - Method in class com.linkedin.venice.client.store.ClientConfig
Deprecated.
setOngoingOfflinePushDetected(boolean) - Method in class com.linkedin.venice.datarecovery.MonitorCommand
 
setOperation(Object) - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
Sets the value of the 'operation' field.
setOperation(String) - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
setOperations(List<ComputeOperation>) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
Sets the value of the 'operations' field.
setOperations(List<Object>) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
Sets the value of the 'operations' field.
setOperations(List<Object>) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
Sets the value of the 'operations' field.
setOperations(List<Object>) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
Sets the value of the 'operations' field.
setOperations(List<Object>) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
Sets the value of the 'operations' field.
setOperationType(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
Sets the value of the 'operationType' field.
setOperationType(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
Sets the value of the 'operationType' field.
setOtherClusters(List<CharSequence>) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Sets the value of the 'otherClusters' field.
setOutboundQueueSizeLimit(int) - Method in class com.linkedin.alpini.netty4.ssl.FusedSslHandler
 
setOverallStatus(List<PushJobDetailsStatusTuple>) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'overallStatus' field.
setOwner(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
setOwner(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
Sets the value of the 'owner' field.
setOwner(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Sets the value of the 'owner' field.
setOwner(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'owner' field.
setOwner(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'owner' field.
setOwner(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'owner' field.
setOwner(String) - Method in class com.linkedin.venice.controllerapi.NewStoreResponse
 
setOwner(String) - Method in class com.linkedin.venice.controllerapi.OwnerResponse
 
setOwner(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setOwner(String) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setOwner(String) - Method in interface com.linkedin.venice.meta.Store
 
setOwner(String) - Method in class com.linkedin.venice.meta.StoreInfo
 
setOwner(String) - Method in class com.linkedin.venice.meta.SystemStore
 
setOwner(String) - Method in class com.linkedin.venice.meta.ZKStore
 
setOwners(List<CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Sets the value of the 'owners' field.
setOwners(List<CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Sets the value of the 'owners' field.
setOwners(Set<String>) - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
setOwners(Set<String>) - Method in class com.linkedin.venice.persona.Persona
 
setParams(EstimateDataRecoveryTimeCommand.Params) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
setParams(MonitorCommand.Params) - Method in class com.linkedin.venice.datarecovery.MonitorCommand
 
setParams(StoreRepushCommand.Params) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
setParentUrl(String) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
setParentUrl(String) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
setParticipantId(String) - Method in class com.linkedin.venice.routerapi.ReplicaState
 
setPartition(int) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
uint32 partition = 1;
setPartition(int) - Method in class com.linkedin.venice.routerapi.ReplicaState
 
setPartitionAssignment(String, PartitionAssignment) - Method in class com.linkedin.venice.helix.ResourceAssignment
 
setPartitionConsumptionState(int, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
setPartitionConsumptionStates(List<ConsumptionStateSnapshot>) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Sets the value of the 'partitionConsumptionStates' field.
setPartitionCount(int) - Method in class com.linkedin.venice.controllerapi.PartitionResponse
 
setPartitionCount(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setPartitionCount(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setPartitionCount(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setPartitionCount(int) - Method in interface com.linkedin.venice.meta.Store
 
setPartitionCount(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setPartitionCount(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'partitionCount' field.
setPartitionCount(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setPartitionCount(int) - Method in interface com.linkedin.venice.meta.Version
 
setPartitionCount(int) - Method in class com.linkedin.venice.meta.VersionImpl
 
setPartitionCount(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setPartitionCount(int) - Method in class com.linkedin.venice.metadata.response.VersionProperties
Sets the value of the 'partitionCount' field.
setPartitionCount(int) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'partitionCount' field.
setPartitionCount(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'partitionCount' field.
setPartitionCount(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'partitionCount' field.
setPartitionCount(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
setPartitionCount(Integer) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'partitionCount' field.
setPartitionCount(Integer) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setPartitionDetails(List<PartitionDetail>) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setPartitioner(VenicePartitioner) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setPartitionerClass(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
Sets the value of the 'partitionerClass' field.
setPartitionerClass(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
Sets the value of the 'partitionerClass' field.
setPartitionerClass(CharSequence) - Method in class com.linkedin.venice.metadata.response.VersionProperties
Sets the value of the 'partitionerClass' field.
setPartitionerClass(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
Sets the value of the 'partitionerClass' field.
setPartitionerClass(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setPartitionerClass(String) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setPartitionerClass(String) - Method in interface com.linkedin.venice.meta.PartitionerConfig
 
setPartitionerClass(String) - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
setPartitionerConfig(PartitionerConfigRecord) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'partitionerConfig' field.
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setPartitionerConfig(PartitionerConfig) - Method in interface com.linkedin.venice.meta.Store
 
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.StoreInfo
 
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.SystemStore
 
setPartitionerConfig(PartitionerConfig) - Method in interface com.linkedin.venice.meta.Version
 
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.VersionImpl
 
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.ZKStore
 
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'partitionerConfig' field.
setPartitionerConfig(PartitionerConfig) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'partitionerConfig' field.
setPartitionerConfig(StorePartitionerConfig) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'partitionerConfig' field.
setPartitionerConfig(StorePartitionerConfig) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'partitionerConfig' field.
setPartitionerParams(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
Sets the value of the 'partitionerParams' field.
setPartitionerParams(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
Sets the value of the 'partitionerParams' field.
setPartitionerParams(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.metadata.response.VersionProperties
Sets the value of the 'partitionerParams' field.
setPartitionerParams(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
Sets the value of the 'partitionerParams' field.
setPartitionerParams(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setPartitionerParams(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setPartitionerParams(Map<String, String>) - Method in interface com.linkedin.venice.meta.PartitionerConfig
 
setPartitionerParams(Map<String, String>) - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
 
setPartitionId(int) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'partitionId' field.
setPartitionId(int) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
Sets the value of the 'partitionId' field.
setPartitionId(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Sets the value of the 'partitionId' field.
setPartitionId(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
Sets the value of the 'partitionId' field.
setPartitionId(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'partitionId' field.
setPartitionId(int) - Method in class com.linkedin.venice.meta.PartitionDetail
 
setPartitionId(int) - Method in class com.linkedin.venice.meta.UncompletedPartition
 
setPartitionId(int) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
Sets the value of the 'partitionId' field.
setPartitionId(int) - Method in class com.linkedin.venice.router.api.RouterKey
 
setPartitionIngestionStatusToIsolatedIngestion(int) - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
setPartitionIngestionStatusToLocalIngestion(int) - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
 
setPartitionKeys(Collection<RouterKey>) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setPartitionNum(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
Sets the value of the 'partitionNum' field.
setPartitionNum(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'partitionNum' field.
setPartitions(int) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setPartitionState(int, OffsetRecord) - Method in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
 
setPartitionState(OffsetRecord, long) - Method in class com.linkedin.davinci.validation.PartitionTracker
 
setPartitionStateSerializer(InternalAvroSpecificSerializer<PartitionState>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setPartitionStatus(PartitionStatus) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setPartitionStatus(PartitionStatus, boolean) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setPartitionStatuses(List<PartitionStatus>) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setPartsInvokeDelayLatency(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setPath(Object) - Method in class com.linkedin.alpini.base.misc.Metrics
 
setPayload(ByteBuffer) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Sets the value of the 'payload' field.
setPayloadUnion(Object) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
Sets the value of the 'payloadUnion' field.
setPayloadUnion(Object) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Sets the value of the 'payloadUnion' field.
setPCtrlCliWithoutCluster(ControllerClient) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
setPCtrlCliWithoutCluster(ControllerClient) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
setPCtrlCliWithoutCluster(ControllerClient) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setPermitHttp2(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setPersistenceType(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'persistenceType' field.
setPersistenceType(PersistenceType) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setPersistenceType(PersistenceType) - Method in interface com.linkedin.venice.meta.Store
 
setPersistenceType(PersistenceType) - Method in class com.linkedin.venice.meta.SystemStore
 
setPersistenceType(PersistenceType) - Method in class com.linkedin.venice.meta.ZKStore
 
setPersistenceType(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'persistenceType' field.
setPipelineSupplier(Supplier<Router4PipelineFactory<C>>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
setPort(int) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setPotentiallyLossyLeaderOffsetRewindCount(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setPreferredSchemaFilter(Predicate<Schema>) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setPreviousStatuses(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'previousStatuses' field.
setPreviousValue(ValueBytes) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Sets the value of the 'previousValue' field.
setProcessedRecordSizeSinceLastSync(long) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
Sets the value of the 'processedRecordSizeSinceLastSync' field.
setProducedOffset(long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
setProducedTimestampMs(long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
setProducerConfigs(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'producerConfigs' field.
setProducerGUID(GUID) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Sets the value of the 'producerGUID' field.
setProducerGUID(GUID) - Method in class com.linkedin.venice.storage.protocol.ChunkId
Sets the value of the 'producerGUID' field.
setProducerMetadata(ProducerMetadata) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
Sets the value of the 'producerMetadata' field.
setProducerPartitionState(GUID, ProducerPartitionState) - Method in class com.linkedin.venice.offsets.OffsetRecord
 
setProducerStates(Map<CharSequence, ProducerPartitionState>) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'producerStates' field.
setProducerTimestampLagThresholdToGoOnlineInSeconds(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Sets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
setProducerTimestampLagThresholdToGoOnlineInSeconds(long) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
Sets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
setProducerTimestampLagThresholdToGoOnlineInSeconds(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Sets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
setProjectionFieldValidationEnabled(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setProjectionFieldValidationEnabled(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setProjectionFieldValidationEnabled(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig
 
setPropertiesList(List<VeniceProperties>) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setProperty(PropertyKey, T) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
setPropertyDiff(Map<String, Map<String, String>>) - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
 
setProtocolVersion(HttpVersion) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
setProtocolVersion(HttpVersion) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
setProtocolVersion(HttpVersion) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
setProtocolVersion(HttpVersion) - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
setPubSubAdminAdapterFactory(PubSubAdminAdapterFactory<PubSubAdminAdapter>) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setPubSubClientsFactory(PubSubClientsFactory) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setPubSubConsumerAdapterFactory(PubSubConsumerAdapterFactory<PubSubConsumerAdapter>) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setPubSubOperationTimeoutMs(long) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setPubSubPropertiesSupplier(TopicManagerContext.PubSubPropertiesSupplier) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setPubSubTopicRepository(PubSubTopicRepository) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setPubSubTopicRepository(PubSubTopicRepository) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setPushEndDateTime(String) - Method in class com.linkedin.venice.meta.ReplicaDetail
 
setPushEndTimestamp(String) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setPushId(CharSequence) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'pushId' field.
setPushJobConfigs(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'pushJobConfigs' field.
setPushJobDetailsStoreClient(AvroSpecificStoreClient<PushJobStatusRecordKey, PushJobDetails>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
setPushJobId(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'pushJobId' field.
setPushJobId(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'pushJobId' field.
setPushJobId(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'pushJobId' field.
setPushJobId(String) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setPushJobId(String) - Method in interface com.linkedin.venice.meta.Version
 
setPushJobId(String) - Method in class com.linkedin.venice.meta.VersionImpl
 
setPushJobLatestCheckpoint(Integer) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'pushJobLatestCheckpoint' field.
setPushProperties(Map<String, String>) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setPushStartDateTime(String) - Method in class com.linkedin.venice.meta.ReplicaDetail
 
setPushStartTimestamp(String) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setPushStrategy(String, String) - Method in class com.linkedin.venice.controller.migration.MigrationPushStrategyZKAccessor
 
setPushStreamSourceAddress(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'pushStreamSourceAddress' field.
setPushStreamSourceAddress(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'pushStreamSourceAddress' field.
setPushStreamSourceAddress(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'pushStreamSourceAddress' field.
setPushStreamSourceAddress(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'pushStreamSourceAddress' field.
setPushStreamSourceAddress(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'pushStreamSourceAddress' field.
setPushStreamSourceAddress(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'pushStreamSourceAddress' field.
setPushStreamSourceAddress(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setPushStreamSourceAddress(String) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setPushStreamSourceAddress(String) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setPushStreamSourceAddress(String) - Method in interface com.linkedin.venice.meta.Store
 
setPushStreamSourceAddress(String) - Method in class com.linkedin.venice.meta.StoreInfo
 
setPushStreamSourceAddress(String) - Method in class com.linkedin.venice.meta.SystemStore
 
setPushStreamSourceAddress(String) - Method in interface com.linkedin.venice.meta.Version
 
setPushStreamSourceAddress(String) - Method in class com.linkedin.venice.meta.VersionImpl
 
setPushStreamSourceAddress(String) - Method in class com.linkedin.venice.meta.ZKStore
 
setPushType(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'pushType' field.
setPushType(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'pushType' field.
setPushType(Version.PushType) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setPushType(Version.PushType) - Method in interface com.linkedin.venice.meta.Version
 
setPushType(Version.PushType) - Method in class com.linkedin.venice.meta.VersionImpl
 
setPushType(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'pushType' field.
setPutOnlyPartLength(int) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
setPutValue(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.Put
Sets the value of the 'putValue' field.
setQosPolicy(String) - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
setQuota(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
setQuotaNumber(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Sets the value of the 'quotaNumber' field.
setQuotaNumber(long) - Method in class com.linkedin.venice.persona.Persona
 
setQuotaNumber(Long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Sets the value of the 'quotaNumber' field.
setQuotaStatus(HybridStoreQuotaStatus) - Method in class com.linkedin.venice.routerapi.HybridStoreQuotaStatusResponse
 
setR2Client(Client) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setR2Client(Client) - Method in class com.linkedin.venice.fastclient.GrpcClientConfig.Builder
 
setRawBytes(ByteBuffer) - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
Sets the value of the 'rawBytes' field.
setRawValue(long) - Method in class com.linkedin.alpini.base.misc.TimeValue
 
setRCU(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
Set the read compute unit (RCU) cost for this response's request
setReadComputationEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'readComputationEnabled' field.
setReadComputationEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setReadComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setReadComputationEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setReadComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setReadComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setReadComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setReadComputationEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'readComputationEnabled' field.
setReadComputationEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'readComputationEnabled' field.
setReadComputeDeserializationLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setReadComputeDeserializationLatency(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setReadComputeDeserializationLatency(double) - Method in class com.linkedin.venice.listener.StatsHandler
 
setReadComputeLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setReadComputeLatency(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setReadComputeLatency(double) - Method in class com.linkedin.venice.listener.StatsHandler
 
setReadComputeOutputSize(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setReadComputeOutputSize(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setReadComputeSerializationLatency(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setReadComputeSerializationLatency(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setReadComputeSerializationLatency(double) - Method in class com.linkedin.venice.listener.StatsHandler
 
setReadMetricsEnabled(boolean) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
setReadMode(NettyUtils.ReadMode) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
setReadMode(String) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
setReadOnly(boolean) - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
setReadQuotaInCU(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'readQuotaInCU' field.
setReadQuotaInCU(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setReadQuotaInCU(long) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setReadQuotaInCU(long) - Method in interface com.linkedin.venice.meta.Store
 
setReadQuotaInCU(long) - Method in class com.linkedin.venice.meta.StoreInfo
 
setReadQuotaInCU(long) - Method in class com.linkedin.venice.meta.SystemStore
 
setReadQuotaInCU(long) - Method in class com.linkedin.venice.meta.ZKStore
 
setReadQuotaInCU(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'readQuotaInCU' field.
setReadQuotaInCU(Long) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'readQuotaInCU' field.
setReadRequestThrottling(boolean) - Method in class com.linkedin.venice.router.RouterServer
 
setReadResponse(ReadResponse) - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setReadStrategy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'readStrategy' field.
setReadStrategy(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'readStrategy' field.
setReadThrottlingEnabled(boolean) - Method in class com.linkedin.venice.router.VeniceRouterConfig
 
setReady(boolean) - Method in class com.linkedin.venice.controllerapi.ReadyForDataRecoveryResponse
 
setReadyToServe(boolean) - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
 
setRealTimeTopicSwitcher(RealTimeTopicSwitcher) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
For testing only; in order to override the topicReplicator with mocked Replicator.
setReason(String) - Method in class com.linkedin.venice.controllerapi.ReadyForDataRecoveryResponse
 
setRecordTransformerFunction(Function<Integer, DaVinciRecordTransformer>) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
setRedirectErrorStream(boolean) - Method in class com.linkedin.alpini.io.ExternalCommand
 
setRefreshIntervalInSeconds(long) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
setRegionName(String) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setRegionPushDetails(RegionPushDetails) - Method in class com.linkedin.venice.controllerapi.RegionPushDetailsResponse
 
setRegionPushDetails(Map<String, RegionPushDetails>) - Method in class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
 
setRegionsFilter(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Sets the value of the 'regionsFilter' field.
setRegionsFilter(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
Sets the value of the 'regionsFilter' field.
setRegionsFilter(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Sets the value of the 'regionsFilter' field.
setRegionsFilter(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
Sets the value of the 'regionsFilter' field.
setRegionsFilter(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
Sets the value of the 'regionsFilter' field.
setRegionsFilter(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'regionsFilter' field.
setRegionsFilter(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setRegionsWithStaleData(ArrayList<String>) - Method in class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
 
setRegularVersionETLEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
Sets the value of the 'regularVersionETLEnabled' field.
setRegularVersionETLEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setRegularVersionETLEnabled(boolean) - Method in interface com.linkedin.venice.meta.ETLStoreConfig
 
setRegularVersionETLEnabled(boolean) - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
 
setRegularVersionETLEnabled(boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
Sets the value of the 'regularVersionETLEnabled' field.
setRegularVersionETLEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Sets the value of the 'regularVersionETLEnabled' field.
setRemoteComputationOnly(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setRemoteIngestionRepairService(RemoteIngestionRepairService) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setRemovable(boolean) - Method in class com.linkedin.venice.controllerapi.NodeStatusResponse
 
setRemoveOnCancelPolicy(boolean) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Sets the policy on whether cancelled tasks should be immediately removed from the work queue at time of cancellation.
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
setRepeatedField(Descriptors.FieldDescriptor, int, Object) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
setReplicaDetails(List<ReplicaDetail>) - Method in class com.linkedin.venice.meta.PartitionDetail
 
setReplicas(int) - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
setReplicas(Replica[]) - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
 
setReplicaStates(List<ReplicaState>) - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
 
setReplicaStatuses(Collection<ReplicaStatus>) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
setReplicateAllConfigs(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'replicateAllConfigs' field.
setReplicateAllConfigs(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setReplicationCheckpointVector(List<Long>) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
Sets the value of the 'replicationCheckpointVector' field.
setReplicationFactor(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'replicationFactor' field.
setReplicationFactor(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setReplicationFactor(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setReplicationFactor(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setReplicationFactor(int) - Method in interface com.linkedin.venice.meta.Store
 
setReplicationFactor(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setReplicationFactor(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setReplicationFactor(int) - Method in interface com.linkedin.venice.meta.Version
 
setReplicationFactor(int) - Method in class com.linkedin.venice.meta.VersionImpl
 
setReplicationFactor(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setReplicationFactor(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'replicationFactor' field.
setReplicationFactor(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'replicationFactor' field.
setReplicationMetadataPayload(ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Sets the value of the 'replicationMetadataPayload' field.
setReplicationMetadataPayload(ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
 
setReplicationMetadataPayload(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.Delete
Sets the value of the 'replicationMetadataPayload' field.
setReplicationMetadataPayload(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.Put
Sets the value of the 'replicationMetadataPayload' field.
setReplicationMetadataRecord(GenericRecord) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
setReplicationMetadataVersionId(int) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Sets the value of the 'replicationMetadataVersionId' field.
setReplicationMetadataVersionId(int) - Method in class com.linkedin.venice.kafka.protocol.Delete
Sets the value of the 'replicationMetadataVersionId' field.
setReplicationMetadataVersionId(int) - Method in class com.linkedin.venice.kafka.protocol.Put
Sets the value of the 'replicationMetadataVersionId' field.
setReplicationMetadataVersionId(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setReplicationMetadataVersionID(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'replicationMetadataVersionID' field.
setReplicationMetadataVersionID(int) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setReplicationMetadataVersionID(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'replicationMetadataVersionID' field.
setReportTimestamp(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'reportTimestamp' field.
setReportTimestamp(Long) - Method in class com.linkedin.venice.pushstatus.PushStatusValue
Sets the value of the 'reportTimestamp' field.
setReportType(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'reportType' field.
setRepushInfo(RepushInfo) - Method in class com.linkedin.venice.controllerapi.RepushInfoResponse
 
setRequestInfo(RouterRequest) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setRequestInfo(RouterRequest) - Method in class com.linkedin.venice.listener.StatsHandler
 
setRequestKeyCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setRequestKeyCount(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setRequestPartCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setRequestRetriableChecker(RequestRetriableChecker<P, R, HTTP_RESPONSE_STATUS>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
setRequestSize(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setRequestSize(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setRequestTerminatedEarly() - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setRequestTerminatedEarly() - Method in class com.linkedin.venice.listener.StatsHandler
 
setRequestTimeOutInMilliseconds(long) - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
setRequestTimeoutInNS(long) - Method in class com.linkedin.venice.listener.request.RouterRequest
 
setRequestType(RequestType) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setRequestType(RequestType) - Method in class com.linkedin.venice.listener.StatsHandler
 
setRequireClientCertOnLocalHost(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setRequireClientCertOnLocalHost(boolean) - Method in class com.linkedin.venice.security.SSLConfig
 
setReservedVersion(int) - Method in class com.linkedin.venice.meta.StoreInfo
 
setResourceName(CharSequence) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
Sets the value of the 'resourceName' field.
setResourceName(String) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string resourceName = 5;
setResourceNameBytes(ByteString) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
string resourceName = 5;
setResourceRegistryThreadLocal() - Method in class com.linkedin.alpini.base.test.ResourceRegistryTestBase
 
setResourceToBeSubscribed(String, int) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
setResourceToBeUnsubscribed(String, int) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
setResponseDecompressor(VeniceResponseDecompressor) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setResponseHeaders(Map<CharSequence, String>) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setResponseObserver(StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setResponseRCU(int) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
uint32 responseRCU = 4;
setResponseStatus(HttpResponseStatus) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setResponseStatus(HttpResponseStatus) - Method in class com.linkedin.venice.listener.StatsHandler
 
setRestoreDataPartitions(boolean) - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
setRestoreMetadataPartition(boolean) - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
setResult(EstimateDataRecoveryTimeCommand.Result) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
 
setResult(RepushViabilityInfo.Result) - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
setResultFieldName(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
Sets the value of the 'resultFieldName' field.
setResultFieldName(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.Count
Sets the value of the 'resultFieldName' field.
setResultFieldName(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
Sets the value of the 'resultFieldName' field.
setResultFieldName(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
Sets the value of the 'resultFieldName' field.
setResultSchemaStr(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
Sets the value of the 'resultSchemaStr' field.
setResultSchemaStr(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
Sets the value of the 'resultSchemaStr' field.
setResultSchemaStr(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
Sets the value of the 'resultSchemaStr' field.
setResultSchemaStr(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
Sets the value of the 'resultSchemaStr' field.
setResultSchemaStr(CharSequence) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
Sets the value of the 'resultSchemaStr' field.
setRetentionInMs(Optional<Long>) - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
setRetryBackOffInMs(long) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setRetryCount(int) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setRetryOnAllErrors(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setRetryOnMaxStreamsLimit(boolean) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
setRetryOnRouterError(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setRetryRequest() - Method in interface com.linkedin.alpini.router.api.ResourcePath
 
setRetryRequest() - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setRetryRequest(HttpResponseStatus) - Method in interface com.linkedin.alpini.router.api.ResourcePath
If the inherited class wants to know whether the current path belongs to a retry request or not, it needs to implement this method properly to maintain the internal state.
setRetryRequest(HttpResponseStatus) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setRewindStartTimestamp(long) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
Sets the value of the 'rewindStartTimestamp' field.
setRewindTimeInSeconds(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
Sets the value of the 'rewindTimeInSeconds' field.
setRewindTimeInSeconds(long) - Method in interface com.linkedin.venice.meta.HybridStoreConfig
 
setRewindTimeInSeconds(long) - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
 
setRewindTimeInSeconds(long) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
Sets the value of the 'rewindTimeInSeconds' field.
setRewindTimeInSeconds(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Sets the value of the 'rewindTimeInSeconds' field.
setRewindTimeInSecondsOverride(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'rewindTimeInSecondsOverride' field.
setRmd(GenericRecord) - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'rmdChunkingEnabled' field.
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setRmdChunkingEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setRmdChunkingEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'rmdChunkingEnabled' field.
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'rmdChunkingEnabled' field.
setRmdChunkingEnabled(boolean) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setRmdManifest(ChunkedValueManifest) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
setRmdManifest(ChunkedValueManifest) - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
setRmdProtocolVersionId(int) - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
setRmdRecord(GenericRecord) - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
setRmdSchema(int, String) - Method in class com.linkedin.venice.ValueAndDerivedSchemaData
 
setRmdValueSchemaId(int) - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
setRmdVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setRmdVersion(int) - Method in interface com.linkedin.venice.meta.Store
 
setRmdVersion(int) - Method in class com.linkedin.venice.meta.SystemStore
 
setRmdVersion(int) - Method in class com.linkedin.venice.meta.ZKStore
 
setRmdVersionId(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setRmdVersionId(int) - Method in interface com.linkedin.venice.meta.Version
 
setRmdVersionId(int) - Method in class com.linkedin.venice.meta.VersionImpl
 
setRocksDBBlockCacheSizeInBytes(long) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setRocksdbOptionsCompressionType(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
 
setRocksDBServerConfig(RocksDBServerConfig) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
 
setRocksDBStat(Statistics) - Method in class com.linkedin.venice.stats.RocksDBStats
 
setRouterAccessController(StaticAccessController) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setRouterClientConfig(ClientConfig) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setRouterRequest(RouterRequest) - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setRouterStats(RouterStats<AggRouterHttpRequestStats>) - Static method in class com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils
 
setRouterUrl(String) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
setRoutesForPartitionMapping(Map<Integer, Set<String>>) - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
 
setRoutingErrorRequestCounterResetDelayMS(long) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setRoutingInfo(Map<CharSequence, List<CharSequence>>) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setRoutingInfo(Map<CharSequence, List<CharSequence>>) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'routingInfo' field.
setRoutingLeakedRequestCleanupThresholdMS(long) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setRoutingPendingRequestCounterInstanceBlockThreshold(int) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setRoutingQuotaExceededRequestCounterResetDelayMS(long) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setRoutingStrategy(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'routingStrategy' field.
setRoutingStrategy(AbstractClientRoutingStrategy) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
For testing only.
setRoutingStrategy(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'routingStrategy' field.
setRoutingUnavailableRequestCounterResetDelayMS(long) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setRunnableForKillIngestionTasksForNonCurrentVersions(Runnable) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setScheduler(ScheduledExecutorService) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
setSchema$(SchemaMeta) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Sets the value of the 'schema' field.
setSchema$(SchemaMeta) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Sets the value of the 'schema' field.
setSchemaAutoRegisteFromPushJobEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'schemaAutoRegisteFromPushJobEnabled' field.
setSchemaAutoRegisterFromPushJobEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
setSchemaAutoRegisterFromPushJobEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setSchemaAutoRegisterFromPushJobEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setSchemaAutoRegisterFromPushJobEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setSchemaAutoRegisterFromPushJobEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setSchemaAutoRegisterFromPushJobEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setSchemaAutoRegisterFromPushJobEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
setSchemaDiff(Map<String, Map<String, String>>) - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
 
setSchemaId(int) - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
Sets the value of the 'schemaId' field.
setSchemaId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Sets the value of the 'schemaId' field.
setSchemaId(int) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Sets the value of the 'schemaId' field.
setSchemaId(int) - Method in class com.linkedin.venice.kafka.protocol.Delete
Sets the value of the 'schemaId' field.
setSchemaId(int) - Method in class com.linkedin.venice.kafka.protocol.Put
Sets the value of the 'schemaId' field.
setSchemaId(int) - Method in class com.linkedin.venice.kafka.protocol.Update
Sets the value of the 'schemaId' field.
setSchemaId(int) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
sint32 schemaId = 1;
setSchemaId(int) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Sets the value of the 'schemaId' field.
setSchemaId(int) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
Sets the value of the 'schemaId' field.
setSchemaIds(List<Integer>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
Sets the value of the 'schemaIds' field.
setSchemaIdSet(Set<Integer>) - Method in class com.linkedin.venice.controllerapi.MultiSchemaIdResponse
 
setSchemaReader(SchemaReader) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setSchemaReader(SchemaReader) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
setSchemaRefreshPeriod(Duration) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setSchemaRepository(ReadOnlySchemaRepository) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setSchemas(MultiSchemaResponse.Schema[]) - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse
 
setSchemaStr(String) - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
 
setSchemaStr(String) - Method in class com.linkedin.venice.controllerapi.SchemaResponse
 
setSchemaType(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
Sets the value of the 'schemaType' field.
setSecondPartLatency(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setSecureRandomAlgorithm(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setSecureUrl(String) - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
 
setSegmentNumber(int) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
Sets the value of the 'segmentNumber' field.
setSegmentNumber(int) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'segmentNumber' field.
setSegmentNumber(int) - Method in class com.linkedin.venice.storage.protocol.ChunkId
Sets the value of the 'segmentNumber' field.
setSegmentStatus(int) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
Sets the value of the 'segmentStatus' field.
setSendLivenessHeartbeatFailureDetails(CharSequence) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'sendLivenessHeartbeatFailureDetails' field.
setSentPushJobDetailsTracker(SentPushJobDetailsTracker) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
setSequenceNumber(int) - Method in class com.linkedin.venice.kafka.validation.Segment
This function should only be used for hybrid store after receiving 'EOP' when skipping a message in the sequence.
setServerConfig(VeniceServerConfig) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setServerConfigs(ServerConfigSnapshot) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Sets the value of the 'serverConfigs' field.
setServerD2Service(String) - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
setServerKafkaFetchQuotaRecordsPerSecond(Map<String, Integer>) - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
setServerKafkaFetchQuotaRecordsPerSecondForRegion(String, int) - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
setServerKafkaFetchQuotaRecordsPerSecondForRegion(String, long) - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
setService(BindableService) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setServiceDiscoveryAnnouncers(List<ServiceDiscoveryAnnouncer>) - Method in class com.linkedin.venice.controller.VeniceControllerContext.Builder
 
setServiceDiscoveryAnnouncers(List<ServiceDiscoveryAnnouncer>) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setServiceName(String) - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
setSessionCacheSize(long) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setSessionTimeout(long) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setShort(CharSequence, short) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
setSingleDecode(boolean) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
 
setSingleGetRouterCacheEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'singleGetRouterCacheEnabled' field.
setSingleGetRouterCacheEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setSingleGetRouterCacheEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'singleGetRouterCacheEnabled' field.
setSize(int) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
Sets the value of the 'size' field.
setSkipCipherCheck(boolean) - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
setSkipKafkaMessage(boolean) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setSorted(boolean) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Sets the value of the 'sorted' field.
setSorted(boolean) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'sorted' field.
setSourceCluster(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Sets the value of the 'sourceCluster' field.
setSourceFabric(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setSourceKafkaCluster(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Sets the value of the 'sourceKafkaCluster' field.
setSourceKafkaServers(List<CharSequence>) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
Sets the value of the 'sourceKafkaServers' field.
setSourceOffsets(List<Long>) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Sets the value of the 'sourceOffsets' field.
setSourceTopicName(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Sets the value of the 'sourceTopicName' field.
setSourceTopicName(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
Sets the value of the 'sourceTopicName' field.
setSourceVersionChunkingEnabled(boolean) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setSourceVersionCompressionStrategy(CompressionStrategy) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setSourceVersionCompressor(VeniceCompressor) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
setSpecificThinClient(AvroSpecificStoreClient<K, T>) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setSpecificValue(Class<T>) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setSpecificValueClass(Class<T>) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setSpecificValueClass(Class<T>) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setSpeculativeQueryEnabled(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setSrcClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
Sets the value of the 'srcClusterName' field.
setSrcClusterName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
Sets the value of the 'srcClusterName' field.
setSrcClusterName(String) - Method in class com.linkedin.venice.controllerapi.StoreMigrationResponse
 
setSslBufferMode(SSLBufferMode) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Assigns SSLBufferMode value.
setSslContext(SSLContext) - Method in class com.linkedin.venice.httpclient5.HttpClient5Utils.HttpClient5Builder
 
setSslContext(SSLContext) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Assigns SSLContext instance.
setSslContextProvider(Provider) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setSslEnabled(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setSslEnabled(boolean) - Method in class com.linkedin.venice.security.SSLConfig
 
setSslFactory(SSLFactory) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setSslFactory(SSLFactory) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
 
setSslFactory(SSLFactory) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setSSLFactory(SSLFactory) - Method in class com.linkedin.venice.fastclient.GrpcClientConfig.Builder
 
setSSLFactory(Optional<SSLFactory>) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
setSSLFactory(Optional<SSLFactory>) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
setSSLFactory(Optional<SSLFactory>) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setSslProperties(Properties) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setSslProtocol(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setSslRequireClientCerts(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setSslRequireClientCerts(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
setSslRequireClientCerts(boolean) - Method in class com.linkedin.venice.security.DefaultSSLFactory
 
setSslRequireClientCerts(boolean) - Method in class com.linkedin.venice.security.SSLConfig
 
setSstFileManager(SstFileManager) - Method in class com.linkedin.davinci.stats.RocksDBMemoryStats
 
setStaleRegions(Map<String, StoreInfo>) - Method in class com.linkedin.venice.meta.StoreDataAudit
 
setStarted(boolean) - Method in class com.linkedin.venice.kafka.validation.Segment
 
setStartOfBufferReplay(StartOfBufferReplay) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'startOfBufferReplay' field.
setStartOfBufferReplayDestinationOffset(Long) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'startOfBufferReplayDestinationOffset' field.
setStartOfPushTimestamp(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setStartOfPushTimestamp(long) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'startOfPushTimestamp' field.
setStartProcessingTimestamp(long) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
 
setStartTime(String) - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
setStatCallBackExecuted(boolean) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setStates(StoreProperties) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
Sets the value of the 'states' field.
setStats(ServerStatsContext, ReadResponse) - Method in class com.linkedin.venice.listener.OutboundHttpWrapperHandler
 
setStats(Optional<ClientStats>) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
setStats(STATS) - Method in class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
 
setStatsPrefix(String) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setStatsPrefix(String) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setStatsSupplier(StatsSupplier<T>) - Method in class com.linkedin.venice.stats.AbstractVeniceAggStats
 
setStatus(int) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Sets the value of the 'status' field.
setStatus(int) - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
Sets the value of the 'status' field.
setStatus(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
Sets the value of the 'status' field.
setStatus(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'status' field.
setStatus(HelixState) - Method in class com.linkedin.venice.helix.Replica
 
setStatus(VersionStatus) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setStatus(VersionStatus) - Method in interface com.linkedin.venice.meta.Version
 
setStatus(VersionStatus) - Method in class com.linkedin.venice.meta.VersionImpl
 
setStatus(ExecutionStatus) - Method in class com.linkedin.venice.meta.UncompletedReplica
 
setStatus(HttpResponseStatus) - Method in class com.linkedin.alpini.netty4.http2.Http1FullResponse
setStatus(HttpResponseStatus) - Method in class com.linkedin.alpini.netty4.http2.Http1Response
setStatus(HttpResponseStatus) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
setStatus(HttpResponseStatus) - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
setStatus(HttpResponseStatus) - Method in interface com.linkedin.alpini.netty4.misc.HttpMultiPart
 
setStatus(CharSequence) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'status' field.
setStatus(String) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setStatus(String) - Method in class com.linkedin.venice.helix.Replica
Used by the JSON deserializer
setStatusDetails(String) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setStatusDetails(String) - Method in class com.linkedin.venice.meta.UncompletedReplica
 
setStatusDetails(String) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
Necessary for the JSON serde
setStatusHistory(List<StatusSnapshot>) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setStatusHistory(List<StatusSnapshot>) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
setStatusUpdateTimestamp(Long) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setStdErrLog(Consumer<String>) - Method in class com.linkedin.alpini.io.SubprocessBuilder
When the process is started , log the process stderr to the Logger.
setStdOut(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
 
setStdOutLog(Consumer<String>) - Method in class com.linkedin.alpini.io.SubprocessBuilder
When the process is started , log the process stdout to the Logger.
setStorageClass(StorageClass) - Method in class com.linkedin.davinci.client.DaVinciConfig
 
setStorageEngine(String, AbstractStorageEngine) - Method in class com.linkedin.davinci.stats.AggVersionedStorageEngineStats
 
setStorageEngineOverheadRatio(double) - Method in class com.linkedin.venice.controllerapi.StorageEngineOverheadRatioResponse
 
setStorageEngineReference(String, AtomicReference<AbstractStorageEngine>) - Method in interface com.linkedin.davinci.ingestion.DaVinciIngestionBackend
 
setStorageEngineReference(String, AtomicReference<AbstractStorageEngine>) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
setStorageEngineRepository(StorageEngineRepository) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setStorageExecutionHandlerSubmissionWaitTime(double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setStorageExecutionHandlerSubmissionWaitTime(double) - Method in class com.linkedin.venice.listener.StatsHandler
 
setStorageExecutionQueueLen(int) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setStorageExecutionQueueLen(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setStorageExecutionQueueLen(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setStorageExecutionSubmissionWaitTime(double) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setStorageMetadataService(MainIngestionStorageMetadataService) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setStorageMetadataService(StorageMetadataService) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setStorageNodeReadQuotaEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'storageNodeReadQuotaEnabled' field.
setStorageNodeReadQuotaEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setStorageNodeReadQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setStorageNodeReadQuotaEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setStorageNodeReadQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setStorageNodeReadQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setStorageNodeReadQuotaEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setStorageNodeReadQuotaEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'storageNodeReadQuotaEnabled' field.
setStoragePersona(StoragePersona) - Method in class com.linkedin.venice.controllerapi.StoragePersonaResponse
 
setStoragePersona(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'storagePersona' field.
setStoragePersona(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setStoragePersonas(List<StoragePersona>) - Method in class com.linkedin.venice.controllerapi.MultiStoragePersonaResponse
 
setStorageQuotaInByte(long) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'storageQuotaInByte' field.
setStorageQuotaInByte(long) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setStorageQuotaInByte(long) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setStorageQuotaInByte(long) - Method in interface com.linkedin.venice.meta.Store
 
setStorageQuotaInByte(long) - Method in class com.linkedin.venice.meta.StoreInfo
 
setStorageQuotaInByte(long) - Method in class com.linkedin.venice.meta.SystemStore
 
setStorageQuotaInByte(long) - Method in class com.linkedin.venice.meta.ZKStore
 
setStorageQuotaInByte(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'storageQuotaInByte' field.
setStorageQuotaInByte(Long) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'storageQuotaInByte' field.
setStore(StoreInfo) - Method in class com.linkedin.venice.controllerapi.StoreResponse
 
setStore(String) - Method in class com.linkedin.venice.datarecovery.Command.Params
 
setStore(String) - Method in class com.linkedin.venice.datarecovery.Command.Result
 
setStoreAccessController(DynamicAccessController) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setStoreBufferService(AbstractStoreBufferService) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setStoreClusterConfig(StoreClusterConfig) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'storeClusterConfig' field.
setStoreConfigForMigration(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update "migrationDestCluster" and "migrationSrcCluster" fields of the "/storeConfigs/storeName" znode.
setStoreCurrentVersion(String, String, int) - Method in interface com.linkedin.venice.controller.Admin
 
setStoreCurrentVersion(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update the current version of a specified store.
setStoreCurrentVersion(String, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
SetStoreCurrentVersion - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
SetStoreCurrentVersion() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
Default constructor.
SetStoreCurrentVersion(CharSequence, CharSequence, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
All-args constructor.
setStoreInfo(StoreInfo) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Result
 
setStoreInfoList(ArrayList<StoreInfo>) - Method in class com.linkedin.venice.controllerapi.MultiStoreInfoResponse
 
setStoreIngestionService(KafkaStoreIngestionService) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setStoreKeySchemas(StoreKeySchemas) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'storeKeySchemas' field.
setStoreLargestUsedVersion(String, String, int) - Method in interface com.linkedin.venice.controller.Admin
 
setStoreLargestUsedVersion(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update the largest used version number of a specified store.
setStoreLargestUsedVersion(String, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
setStoreMetadataFetchMode(StoreMetadataFetchMode) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setStoreMetadataSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setStoreMetadataSystemStoreEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setStoreMetadataSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setStoreMetadataSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setStoreMetadataSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setStoreMetadataSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'storeMetadataSystemStoreEnabled' field.
setStoreMetaSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setStoreMetaSystemStoreEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setStoreMetaSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setStoreMetaSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setStoreMetaSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setStoreMetaSystemStoreEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'storeMetaSystemStoreEnabled' field.
setStoreMigration(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setStoreMigrationAllowed(boolean) - Method in class com.linkedin.venice.controllerapi.StoreMigrationResponse
 
setStoreMigrationAllowed(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
setStoreMigrationAllowed(boolean) - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Sets the value of the 'storeName' field.
setStoreName(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'storeName' field.
setStoreName(String) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setStoreName(String) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setStoreName(String) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setStoreName(String) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setStoreName(String) - Method in class com.linkedin.venice.listener.StatsHandler
 
setStoreName(String) - Method in class com.linkedin.venice.meta.StoreDataAudit
 
setStoreName(String) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setStoreOwner(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
setStoreOwner(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
 
setStoreOwner(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update the owner of a specified store.
setStoreOwner(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Update the owner of a specified store by sending SET_STORE_OWNER admin message to the admin topic.
SetStoreOwner - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
SetStoreOwner() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
Default constructor.
SetStoreOwner(CharSequence, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
All-args constructor.
setStorePartitionCount(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
setStorePartitionCount(String, String, int) - Method in interface com.linkedin.venice.controller.Admin
 
setStorePartitionCount(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Since partition check/calculation only happens when adding new store version, VeniceHelixAdmin.setStorePartitionCount(String, String, int) would only change the number of partition for the following pushes.
setStorePartitionCount(String, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Update the partition count of a specified store by sending SET_STORE_PARTITION admin message to the admin topic.
SetStorePartitionCount - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
SetStorePartitionCount() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
Default constructor.
SetStorePartitionCount(CharSequence, CharSequence, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
All-args constructor.
setStorePersistenceType(PersistenceType) - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
This reason to create a `setter` for VeniceStoreVersionConfig.storePersistenceType since it is unknown sometimes when initializing VeniceStoreVersionConfig, such as in com.linkedin.venice.helix.VeniceStateModelFactory#createNewStateModel, The new state model could be created for a brand-new store or an existing store.
setStoreProperties(StoreProperties) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'storeProperties' field.
setStorePushStrategyForMigration(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
setStorePushStrategyForMigration(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Unsupported operation in the child controller.
setStorePushStrategyForMigration(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
setStoreReadability(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
setStoreReadability(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update the readability of a specified store.
setStoreReadability(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Update the readability of a specified store by sending ENABLE_STORE_READ or DISABLE_STORE_READ admin message.
setStoreReadWriteability(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
setStoreReadWriteability(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update both readability and writability of a specified store.
setStoreReadWriteability(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Update both readability and writability of a specified store.
setStoreReplicaStatuses(Map<CharSequence, StoreReplicaStatus>) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'storeReplicaStatuses' field.
setStoreRepository(ThinClientMetaStoreBasedRepository) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
setStoreRepository(ReadOnlyStoreRepository) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setStores(String[]) - Method in class com.linkedin.venice.controllerapi.MultiStoreResponse
 
setStoreStatusMap(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.MultiStoreStatusResponse
 
setStoresToEnforce(List<CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
Sets the value of the 'storesToEnforce' field.
setStoresToEnforce(List<CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Sets the value of the 'storesToEnforce' field.
setStoresToEnforce(Set<String>) - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
setStoresToEnforce(Set<String>) - Method in class com.linkedin.venice.persona.Persona
 
setStoreTokenBucket(String, TokenBucket) - Method in class com.linkedin.venice.stats.AggServerQuotaUsageStats
 
setStoreType(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
Sets the value of the 'storeType' field.
setStoreType(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
Sets the value of the 'storeType' field.
setStoreUserPartitionMapping(Map<CharSequence, List<Integer>>) - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
Sets the value of the 'storeUserPartitionMapping' field.
setStoreValueSchema(StoreValueSchema) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'storeValueSchema' field.
setStoreValueSchemaIdsWrittenPerStoreVersion(List<Integer>) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'storeValueSchemaIdsWrittenPerStoreVersion' field.
setStoreValueSchemas(StoreValueSchemas) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'storeValueSchemas' field.
setStoreVersion(int) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
Sets the value of the 'storeVersion' field.
setStoreVersionState(Object) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Sets the value of the 'storeVersionState' field.
setStoreVersionState(ByteBuffer) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'storeVersionState' field.
setStoreViews(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setStoreWriteability(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
setStoreWriteability(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update the writability of a specified store.
setStoreWriteability(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Update the writability of a specified store by sending ENABLE_STORE_WRITE or DISABLE_STORE_WRITE admin message.
setStrategies(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.MigrationPushStrategyResponse
 
setStreamingResponse() - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setStreamReprocessingExitMode(SamzaExitMode) - Method in class com.linkedin.venice.pushmonitor.RouterBasedPushMonitor
 
setSuccess() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
setSuccess() - Method in class io.netty.bootstrap.PendingConnectPromise
 
setSuccess(Void) - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
setSuccess(Void) - Method in class io.netty.bootstrap.PendingConnectPromise
 
setSuccess(T) - Method in interface com.linkedin.alpini.base.concurrency.AsyncPromise
Marks this future as a success and notifies all listeners.
setSuccess(T) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
 
setSuccess(T) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
Marks this future as a success and notifies all listeners.
setSuccess(T) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Marks this future as a success and notifies all listeners.
setSuccess(V) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
setSuccessCodePredicate(IntPredicate) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
 
setSuccessfulPushDurationInSecs(long) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
setSuccessMsg(long) - Method in class com.linkedin.davinci.stats.DIVStats
 
setSuccessRequestKeyCount(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setSuccessRequestKeyCount(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setSupersetSchema(SchemaMeta) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Sets the value of the 'supersetSchema' field.
setSuperSetSchemaAutoGenerationForReadComputeEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setSuperSetSchemaAutoGenerationForReadComputeEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'superSetSchemaAutoGenerationForReadComputeEnabled' field.
setSupersetSchemaId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Sets the value of the 'supersetSchemaId' field.
setSuperSetSchemaId(int) - Method in class com.linkedin.venice.controllerapi.MultiSchemaIdResponse
 
setSuperSetSchemaId(int) - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse
 
setSystemSchemaClusterD2ServiceName(String) - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
setSystemSchemaClusterD2ZkHost(String) - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
setSystemStore(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'systemStore' field.
setSystemStores(Map<CharSequence, SystemStoreProperties>) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'systemStores' field.
setSystemStores(Map<String, SystemStoreAttributes>) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setSystemStores(Map<String, SystemStoreAttributes>) - Method in interface com.linkedin.venice.meta.Store
 
setSystemStores(Map<String, SystemStoreAttributes>) - Method in class com.linkedin.venice.meta.SystemStore
 
setSystemStores(Map<String, SystemStoreAttributes>) - Method in class com.linkedin.venice.meta.ZKStore
 
setTargetedRegions(List<CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'targetedRegions' field.
setTargetRegion(String) - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params.Builder
 
setTargetRegion(String) - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params.Builder
 
setTargetVersionStates(List<StoreVersionState>) - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
Sets the value of the 'targetVersionStates' field.
setTestSuccessful(Predicate<Throwable>) - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
setThinClientForMetaStore(AvroSpecificStoreClient<StoreMetaKey, StoreMetaValue>) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
SetThreadDescription(int, WString) - Method in interface com.linkedin.alpini.jna.ThreadUtils.WindowsCLib
 
setThreadName() - Static method in class com.linkedin.alpini.jna.ThreadUtils
 
setThreadName(String) - Static method in class com.linkedin.alpini.jna.ThreadUtils
 
setThrottlingEnabled(boolean) - Method in class com.linkedin.venice.meta.RoutersClusterConfig
 
setTime(long) - Method in class com.linkedin.venice.utils.TestMockTime
 
setTime(Time) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setTime(Time) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
test-only
setTime(Time) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setTimedOut(boolean) - Method in class com.linkedin.alpini.io.ExternalCommand
 
setTimeout(int) - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
setTimestamp(long) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class com.linkedin.venice.participant.protocol.KillPushJob
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
Sets the value of the 'timestamp' field.
setTimestamp(long) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Sets the value of the 'timestamp' field.
setTimestamp(LocalDateTime) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setTimestampAfterProduce(long) - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
setTimestampBeforeProduce(long) - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
setTimestampMetadataVersionId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'timestampMetadataVersionId' field.
setTimestampMetadataVersionId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Sets the value of the 'timestampMetadataVersionId' field.
setTimestampMetadataVersionId(int) - Method in interface com.linkedin.venice.meta.Version
Deprecated.
setTimestampMetadataVersionId(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'timestampMetadataVersionId' field.
setTimestampPolicy(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
Sets the value of the 'timestampPolicy' field.
setTlsDetailsFactory(Factory<SSLEngine, TlsDetails>) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Assigns TlsDetails Factory instance.
setTlsVersions(String...) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Assigns enabled TLS versions.
setTlsVersions(TLS...) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Assigns enabled TLS versions.
setTokenBucket(TokenBucket) - Method in class com.linkedin.venice.stats.ServerQuotaUsageStats
 
setTopicCompaction(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
setTopicConfig(PubSubTopic, PubSubTopicConfiguration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
Sets the configuration for a Kafka topic.
setTopicConfig(PubSubTopic, PubSubTopicConfiguration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
Sets the configuration for a PubSub topic.
setTopicConfig(PubSubTopic, PubSubTopicConfiguration) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
 
setTopicConfigCache(Cache<PubSubTopic, PubSubTopicConfiguration>) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
setTopicConfigsResponse(String) - Method in class com.linkedin.venice.controllerapi.PubSubTopicConfigResponse
 
setTopicDeletionStatusPollIntervalMs(long) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setTopicIngestionToFollowerState(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setTopicManagerRepository(TopicManagerRepository) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setTopicMetadataFetcherConsumerPoolSize(int) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setTopicMetadataFetcherThreadPoolSize(int) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setTopicMinLogCompactionLagMs(long) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setTopicName(CharSequence) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
Sets the value of the 'topicName' field.
setTopicName(CharSequence) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
Sets the value of the 'topicName' field.
setTopicName(CharSequence) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
Sets the value of the 'topicName' field.
setTopicName(String) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer.ParamBuilder
 
setTopicOffsetCheckIntervalMs(long) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
setTopicPartition(PubSubTopicPartition) - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
setTopicPartitionIngestionContext(byte[]) - Method in class com.linkedin.davinci.listener.response.TopicPartitionIngestionContextResponse
 
setTopicPartitionToLeaderState(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setTopics(List<String>) - Method in class com.linkedin.venice.controllerapi.MultiStoreTopicsResponse
 
setTopicSwitch(TopicSwitchWrapper) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
Update the in-memory state for TopicSwitch whenever encounter a new TopicSwitch message or after a restart.
setTopicSwitch(TopicSwitch) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Sets the value of the 'topicSwitch' field.
setTopLevelColoID(int) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
setTopLevelFieldTimestamp(long) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
setTotalCompressedValueBytes(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'totalCompressedValueBytes' field.
setTotalGzipCompressedValueBytes(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'totalGzipCompressedValueBytes' field.
setTotalKeyBytes(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'totalKeyBytes' field.
setTotalNumberOfRecords(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'totalNumberOfRecords' field.
setTotalRawValueBytes(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'totalRawValueBytes' field.
setTotalStats(STATS) - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
setTotalZstdWithDictCompressedValueBytes(long) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'totalZstdWithDictCompressedValueBytes' field.
setTrace(boolean) - Method in class com.linkedin.alpini.log.FastLog
 
setTrace(boolean) - Method in interface com.linkedin.alpini.log.FastLogMBean
 
setTrailerHeaders(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Sets the value of the 'trailerHeaders' field.
setTransientRecord(int, long, byte[], byte[], int, int, int, GenericRecord) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setTransientRecord(int, long, byte[], int, GenericRecord) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
setTrustStoreFilePassword(String) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setTrustStoreFilePassword(String) - Method in class com.linkedin.venice.security.SSLConfig
 
setTrustStoreFilePath(String) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setTrustStoreFilePath(String) - Method in class com.linkedin.venice.security.SSLConfig
 
setTrustStoreManagerAlgorithm(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setTrustStorePassword(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setTrustStorePath(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setTrustStoreType(String) - Method in class com.linkedin.venice.security.SSLConfig
 
setTrustStoreType(String) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setTtlInMilliseconds(Long) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
setType(int) - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
Sets the value of the 'type' field.
setUncancellable() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
setUncompletedPartitions(List<UncompletedPartition>) - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
 
setUncompletedPartitions(List<UncompletedPartition>) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setUncompletedReplicas(List<UncompletedReplica>) - Method in class com.linkedin.venice.meta.UncompletedPartition
 
setUnit(TimeUnit) - Method in class com.linkedin.alpini.base.misc.TimeValue
 
setUnitTestMode() - Static method in class com.linkedin.venice.client.store.ClientFactoryTestUtils
 
setUnitTestMode() - Static method in class com.linkedin.venice.d2.D2ClientFactory
 
setUnknownFields(UnknownFieldSet) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
 
setUnknownFields(UnknownFieldSet) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
 
setUnreadyReplicas(List<Replica>) - Method in class com.linkedin.venice.controllerapi.NodeReplicasReadinessResponse
 
setUnretrievablePartitions(List<Integer>) - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
 
setUnusedSchemaDeletionEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'unusedSchemaDeletionEnabled' field.
setUnusedSchemaDeletionEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setUnusedSchemaDeletionEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setUnusedSchemaDeletionEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setUnusedSchemaDeletionEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setUnusedSchemaDeletionEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setUnusedSchemaDeletionEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setUnusedSchemaDeletionEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'unusedSchemaDeletionEnabled' field.
setupClientsAndReInitProvider() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
setUpcomingAggregates(List<CharSequence>) - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
Sets the value of the 'upcomingAggregates' field.
setupCommonJobConf(VeniceProperties, JobConf, String, PushJobSetting) - Static method in class com.linkedin.venice.hadoop.mapreduce.common.JobUtils
Common configuration for all the Mapreduce Jobs run as part of VPJ
setupContext(Provider, Object, String, String, File, String, long, long, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
setupContext(Provider, Object, String, String, File, String, long, long, boolean, boolean) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
setupCustomizedStateConfig(HelixAdmin, String) - Static method in class com.linkedin.venice.utils.HelixUtils
This method tells helix what properties to aggregate for customized view.
setUpdatedConfigsList(List<CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'updatedConfigsList' field.
setUpdatedConfigsList(List<String>) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setUpdateIgnored(boolean) - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
setUpdateSchema(int, String) - Method in class com.linkedin.venice.ValueAndDerivedSchemaData
 
setUpdateSchemaId(int) - Method in class com.linkedin.venice.kafka.protocol.Update
Sets the value of the 'updateSchemaId' field.
setUpdateValue(ByteBuffer) - Method in class com.linkedin.venice.kafka.protocol.Update
Sets the value of the 'updateValue' field.
setupInputFormatConf(JobConf, PushJobSetting) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
 
setupInputFormatConfToValidateSchemaAndBuildDict(JobConf, PushJobSetting, String) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
setupInstanceConfig(String, String, String) - Static method in class com.linkedin.venice.utils.HelixUtils
 
setupNewStorePartition() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
set up a new store partition and start the ingestion
setupResource(Resource) - Method in interface com.linkedin.venice.authorization.AuthorizerService
This may perform any initialization steps that may be necessary before start provisioning any ACL's for a resource.
setupResponseAndFlush(HttpResponseStatus, byte[], boolean, ChannelHandlerContext) - Static method in class com.linkedin.venice.utils.NettyUtils
 
setupRetryRelatedInfo(VenicePath) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
setupRetryRelatedInfo(VenicePath) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setupSSLConfig(Properties, Credentials) - Method in interface com.linkedin.venice.hadoop.ssl.SSLConfigurator
 
setupSSLConfig(Properties, Credentials) - Method in class com.linkedin.venice.hadoop.ssl.TempFileSSLConfigurator
 
setUpstreamKafkaClusterId(int) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Sets the value of the 'upstreamKafkaClusterId' field.
setUpstreamOffset(long) - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
 
setUpstreamOffset(long) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Sets the value of the 'upstreamOffset' field.
setUpstreamOffsetMap(Map<String, Long>) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'upstreamOffsetMap' field.
setUpstreamVersionTopicOffset(long) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
Sets the value of the 'upstreamVersionTopicOffset' field.
setupSystemStore(String, String, AvroProtocolDefinition, Schema, Function<Store, Boolean>, UpdateStoreQueryParams, Admin, VeniceControllerMultiClusterConfig) - Static method in class com.linkedin.venice.controller.init.SystemStoreInitializationHelper
The main function that initializes and configures shared system stores
setupVeniceHeaders(BiConsumer<String, String>) - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
setupVeniceHeaders(BiConsumer<String, String>) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
setupVersionSupplier(AbstractStore.StoreVersionSupplier) - Method in class com.linkedin.venice.meta.AbstractStore
This function should be invoked only once.
setUri(String) - Method in class com.linkedin.alpini.netty4.http2.Http1FullRequest
setUri(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Request
setUri(String) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
setUri(String) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
setUrl(String) - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
 
setUrl(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
 
setUseBlackHoleDeserializer(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setUseCustomH2Codec(boolean) - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
setUseFastAvro(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setUseGrpc(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
 
setUseInsecureLegacyTlsProtocolBecauseOfBrokenPeersUsingAncientJdk(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setUseKafkaKeySerializer(boolean) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setUseOpenSsl(boolean) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setUseQueueSizeForAcquiredChannelCount(BooleanSupplier) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
setUseRefCount(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
 
setUseVersionLevelHybridConfig(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setUseVersionLevelHybridConfig(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setUseVersionLevelHybridConfig(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setUseVersionLevelHybridConfig(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'useVersionLevelHybridConfig' field.
setUseVersionLevelIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setUseVersionLevelIncrementalPushEnabled(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setUseVersionLevelIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setUseVersionLevelIncrementalPushEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'useVersionLevelIncrementalPushEnabled' field.
setUsingFastPool(boolean) - Method in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
setValidateCertificates(boolean) - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration.Builder
 
setValidateProjectionFields(boolean) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
setValidateSchemaAndBuildDictionaryOutputDirPath(JobConf) - Static method in class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictOutputFormat
1.
setValidateSchemaAndBuildDictMapperOutputReader(ValidateSchemaAndBuildDictMapperOutputReader) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
setValue(KafkaMessageEnvelope) - Method in class com.linkedin.venice.utils.PubSubHelper.MutablePubSubMessage
 
setValue(ByteBuffer) - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
Sets the value of the 'value' field.
setValue(ByteBuffer) - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
Sets the value of the 'value' field.
setValue(ByteBuffer) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Sets the value of the 'value' field.
setValue(ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Sets the value of the 'value' field.
setValue(ByteBuffer) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Sets the value of the 'value' field.
setValue(T) - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
setValue(V) - Method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
 
setValueCompressionStrategy(int) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
Sets the value of the 'valueCompressionStrategy' field.
setValueManifest(ChunkedValueManifest) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
setValueRecord(ValueRecord) - Method in class com.linkedin.venice.listener.response.StorageResponseObject
 
setValueSchema(SchemaMeta) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Sets the value of the 'valueSchema' field.
setValueSchema(SchemaMeta) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Sets the value of the 'valueSchema' field.
setValueSchema(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
Sets the value of the 'valueSchema' field.
setValueSchema(Schema) - Method in class com.linkedin.venice.utils.PushInputSchemaBuilder
 
setValueSchemaId(int) - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
 
setValueSchemaId(int) - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
 
setValueSchemaId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
Sets the value of the 'valueSchemaId' field.
setValueSchemaId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
Sets the value of the 'valueSchemaId' field.
setValueSchemaId(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Sets the value of the 'valueSchemaId' field.
setValueSchemaMap(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
Sets the value of the 'valueSchemaMap' field.
setValueSchemaMap(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
Sets the value of the 'valueSchemaMap' field.
setValueSchemas(Map<CharSequence, CharSequence>) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setValueSchemas(Map<CharSequence, CharSequence>) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'valueSchemas' field.
setValueSerializer(VeniceKafkaSerializer) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setValueSize(int) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setValueSize(int) - Method in class com.linkedin.venice.listener.StatsHandler
 
setValueSizeList(IntList) - Method in class com.linkedin.davinci.listener.response.ReadResponse
 
setValueSizeList(IntList) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
setValueSizeList(IntList) - Method in class com.linkedin.venice.listener.StatsHandler
 
setValueType(MapperValueType) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
Sets the value of the 'valueType' field.
setVeniceClientRequest(VeniceClientRequest) - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setVeniceConfigLoader(VeniceConfigLoader) - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
 
setVeniceDiscoveryUrl(String) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setVenicePushStatus(ExecutionStatus) - Method in class com.linkedin.venice.routerapi.ReplicaState
 
setVenicePushStatus(String) - Method in class com.linkedin.venice.routerapi.ReplicaState
 
setVeniceRouterUrl(String) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setVeniceServerResponseBuilder(VeniceServerResponse.Builder) - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
 
setVeniceURL(String) - Method in class com.linkedin.venice.client.store.ClientConfig
 
setVeniceViewWriterFactory(VeniceViewWriterFactory) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setVeniceWriter(AbstractVeniceWriter) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
setVeniceWriter(AbstractVeniceWriter) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
 
setVeniceWriter(VeniceWriter<KafkaKey, byte[], byte[]>) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
setVeniceWriterFactory(VeniceWriterFactory) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setVersion(int) - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
setVersion(int) - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
 
setVersion(int) - Method in class com.linkedin.venice.controllerapi.routes.PushJobStatusUploadResponse
 
setVersion(int) - Method in class com.linkedin.venice.controllerapi.VersionResponse
 
setVersion(Version) - Method in class com.linkedin.venice.controllerapi.RepushInfo
 
setVersion(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
Sets the value of the 'version' field.
setVersion(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
Sets the value of the 'version' field.
setVersion(CharSequence) - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
Sets the value of the 'version' field.
setVersionedDIVStats(AggVersionedDIVStats) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setVersionedIngestionStats(AggVersionedIngestionStats) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
 
setVersionMetadata(VersionProperties) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setVersionMetadata(VersionProperties) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'versionMetadata' field.
setVersionNum(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'versionNum' field.
setVersionNum(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
Sets the value of the 'versionNum' field.
setVersionNumber(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Sets the value of the 'versionNumber' field.
setVersionNumber(int) - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
Sets the value of the 'versionNumber' field.
setVersionPartitionToIsolatedIngestion(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setVersionPartitionToLocalIngestion(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
setVersions(int[]) - Method in class com.linkedin.venice.controllerapi.MultiVersionResponse
 
setVersions(ArrayList<Integer>) - Method in class com.linkedin.venice.meta.RegionPushDetails
 
setVersions(List<Version>) - Method in class com.linkedin.venice.meta.AbstractStore
 
setVersions(List<Version>) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setVersions(List<Version>) - Method in interface com.linkedin.venice.meta.Store
 
setVersions(List<Version>) - Method in class com.linkedin.venice.meta.StoreInfo
 
setVersions(List<Version>) - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
 
setVersions(List<Version>) - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
setVersions(List<Version>) - Method in class com.linkedin.venice.meta.ZKStore
 
setVersions(List<StoreVersion>) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'versions' field.
setVersions(List<StoreVersion>) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Sets the value of the 'versions' field.
setVersions(List<Integer>) - Method in class com.linkedin.davinci.listener.response.MetadataResponse
 
setVersions(List<Integer>) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Sets the value of the 'versions' field.
setVersionStateDiff(Map<String, Map<Integer, VersionStatus>>) - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
 
setVersionStatusMap(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.MultiVersionStatusResponse
 
setVersionSwapDeferred(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Sets the value of the 'versionSwapDeferred' field.
setVersionSwapDeferred(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setVersionSwapDeferred(boolean) - Method in interface com.linkedin.venice.meta.Version
 
setVersionSwapDeferred(boolean) - Method in class com.linkedin.venice.meta.VersionImpl
 
setVersionSwapDetectionIntervalTimeInMs(long) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setViable(boolean) - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
setViewClassGetter(VeniceChangelogConsumerClientFactory.ViewClassGetter) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
 
setViewClassName(CharSequence) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
Sets the value of the 'viewClassName' field.
setViewClassName(CharSequence) - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
Sets the value of the 'viewClassName' field.
setViewClassName(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setViewClassName(String) - Method in class com.linkedin.venice.meta.ReadOnlyViewConfig
 
setViewClassName(String) - Method in interface com.linkedin.venice.meta.ViewConfig
 
setViewClassName(String) - Method in class com.linkedin.venice.meta.ViewConfigImpl
 
setViewClassParams(Map<String, String>) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setViewConfigs(Map<String, ViewConfig>) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
setViewConfigs(Map<String, ViewConfig>) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setViewConfigs(Map<String, ViewConfig>) - Method in interface com.linkedin.venice.meta.Store
 
setViewConfigs(Map<String, ViewConfig>) - Method in class com.linkedin.venice.meta.StoreInfo
 
setViewConfigs(Map<String, ViewConfig>) - Method in class com.linkedin.venice.meta.SystemStore
 
setViewConfigs(Map<String, ViewConfig>) - Method in interface com.linkedin.venice.meta.Version
 
setViewConfigs(Map<String, ViewConfig>) - Method in class com.linkedin.venice.meta.VersionImpl
 
setViewConfigs(Map<String, ViewConfig>) - Method in class com.linkedin.venice.meta.ZKStore
 
setViewName(String) - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
 
setViewName(String) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setViewParameters(Map<String, CharSequence>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
Sets the value of the 'viewParameters' field.
setViewParameters(Map<String, CharSequence>) - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
Sets the value of the 'viewParameters' field.
setViewParameters(Map<String, String>) - Method in class com.linkedin.venice.meta.ReadOnlyViewConfig
 
setViewParameters(Map<String, String>) - Method in interface com.linkedin.venice.meta.ViewConfig
 
setViewParameters(Map<String, String>) - Method in class com.linkedin.venice.meta.ViewConfigImpl
 
setViews(Map<CharSequence, StoreViewConfig>) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'views' field.
setViews(Map<String, StoreViewConfigRecord>) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'views' field.
setViews(Map<String, StoreViewConfig>) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
Sets the value of the 'views' field.
setVsonClient(boolean) - Method in class com.linkedin.venice.client.store.ClientConfig
Deprecated.
setVsonStore(boolean) - Method in class com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder
Deprecated.
setVsonStoreList(List<String>) - Method in class com.linkedin.venice.client.VeniceStoreClientGlobalConfig
 
setWarmUpInstancesFutures(Map<String, CompletableFuture>) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
setWorkingDirectory(File) - Method in class com.linkedin.alpini.io.ExternalCommand
 
setWriteComputationEnabled(boolean) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Sets the value of the 'writeComputationEnabled' field.
setWriteComputationEnabled(boolean) - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
setWriteComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
setWriteComputationEnabled(boolean) - Method in interface com.linkedin.venice.meta.Store
 
setWriteComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.StoreInfo
 
setWriteComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.SystemStore
 
setWriteComputationEnabled(boolean) - Method in class com.linkedin.venice.meta.ZKStore
 
setWriteComputationEnabled(boolean) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
Sets the value of the 'writeComputationEnabled' field.
setWriteComputationEnabled(Boolean) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Sets the value of the 'writeComputationEnabled' field.
setWriteComputeSerializer(VeniceKafkaSerializer) - Method in class com.linkedin.venice.writer.VeniceWriterOptions.Builder
 
setWriteMessageCallback(VeniceChunkedWriteHandler.WriteMessageCallback) - Method in class com.linkedin.venice.router.streaming.VeniceChunkedWriteHandler
 
setWriteOnlyConfig(boolean) - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
setWriterConfig(Map<String, String>) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
setZkAddress(String) - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
setZstdDictionary(ByteBuffer) - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
Sets the value of the 'zstdDictionary' field.
SEVER_CALCULATE_QUOTA_USAGE_BASED_ON_PARTITIONS_ASSIGNMENT_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Set to true to enable disk quota usage based on partitions assignment reported by the storage node
shadowReadMetaStore(VenicePath, FullHttpResponse) - Method in class com.linkedin.venice.router.api.MetaStoreShadowReader
This method performs shadow read for meta system store request in Router.
SHARED_KAFKA_PRODUCER_BATCH_SIZE - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.SharedKafkaProducerConfig
 
SHARED_KAFKA_PRODUCER_CONFIG_PREFIX - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.SharedKafkaProducerConfig
 
SHARED_OBJECT_FACTORY - Static variable in class com.linkedin.venice.d2.D2ClientFactory
 
sharedClients - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
 
SharedHelixReadOnlyZKSharedSchemaRepository - Class in com.linkedin.venice.controller.helix
This class is intended to only be used in Controller, which is sharing one instance across all the clusters.
SharedHelixReadOnlyZKSharedSchemaRepository(HelixReadOnlyZKSharedSystemStoreRepository, ZkClient, HelixAdapterSerializer, String, int, long) - Constructor for class com.linkedin.venice.controller.helix.SharedHelixReadOnlyZKSharedSchemaRepository
 
SharedHelixReadOnlyZKSharedSystemStoreRepository - Class in com.linkedin.venice.controller.helix
This class is intended to only be used in Controller, which is sharing one instance across all the clusters.
SharedHelixReadOnlyZKSharedSystemStoreRepository(ZkClient, HelixAdapterSerializer, String) - Constructor for class com.linkedin.venice.controller.helix.SharedHelixReadOnlyZKSharedSystemStoreRepository
 
SharedInternalRTStoreInitializationRoutine - Class in com.linkedin.venice.controller.init
 
SharedInternalRTStoreInitializationRoutine(String, String, AvroProtocolDefinition, VeniceControllerMultiClusterConfig, Admin, Schema, UpdateStoreQueryParams) - Constructor for class com.linkedin.venice.controller.init.SharedInternalRTStoreInitializationRoutine
 
SharedKafkaProducerConfig - Class in com.linkedin.venice.pubsub.adapter.kafka.producer
A class containing shared kafka producer related configurations.
SharedKafkaProducerConfig() - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.producer.SharedKafkaProducerConfig
 
SharedObjectFactory<T> - Class in com.linkedin.venice.utils
A factory class to create shared objects that need to release resources cleanly.
SharedObjectFactory() - Constructor for class com.linkedin.venice.utils.SharedObjectFactory
 
SHORT_WRAPPER - Static variable in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
Deprecated.
 
shortOpt() - Method in annotation type com.linkedin.alpini.cli.CLIArgument
Short name for the option.
shortOpt() - Method in annotation type com.linkedin.alpini.cli.CLIFlag
Short name for the option.
shouldBuildZstdCompressionDictionary(PushJobSetting, boolean) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
This functions decides whether Zstd compression dictionary needs to be trained or not, based on the type of push, configs and whether there are any input records or not, or whether PushJobSetting.compressionMetricCollectionEnabled is enabled or not.
shouldCheckLeaderCompleteStateInFollower() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
shouldCheckLeaderCompleteStateInFollower() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
For non AA hybrid stores with AGGREGATE DRP, SIT reads from parent RT while the HB is written to the child RTs.
shouldCheckLeaderCompleteStateInFollower() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
shouldCloseChannel() - Method in exception com.linkedin.alpini.router.api.RouterException
 
shouldCompressData(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
shouldNewLeaderSwitchToRemoteConsumption(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
shouldPathBeIgnored(Path) - Static method in class com.linkedin.venice.hadoop.utils.HadoopUtils
Check if the path should be ignored.
shouldPerformShadowRead(VenicePath, FullHttpResponse) - Method in class com.linkedin.venice.router.api.MetaStoreShadowReader
 
shouldPersistRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
Additional safeguards in Leader/Follower ingestion: 1.
shouldPersistRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
shouldProcessRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, int) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
For Leader/Follower model, the follower should have the same kind of check as the Online/Offline model; for leader, it's possible that it consumers from real-time topic or GF topic.
shouldProcessRecord(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Common record check for different state models: check whether server continues receiving messages after EOP for a batch-only store.
shouldProduceToVersionTopic(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
For the corresponding partition being tracked in `partitionConsumptionState`, if it's in LEADER state and it's not consuming from version topic, it should produce the new message to version topic; besides, if LEADER is consuming remotely, it should also produce to local fabric.
shouldRequestBeTerminatedEarly() - Method in class com.linkedin.venice.listener.request.RouterRequest
 
shouldRetryOnMaxStreamsLimit() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
shouldUpdateUpstreamOffset(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Validate if the given consumerRecord has a valid upstream offset to update from.
SHOW_SCHEMAS - com.linkedin.venice.Command
 
showUsage(boolean) - Method in class com.linkedin.alpini.cli.CLIArgumentParser
Display command line usage information.
showUsage(boolean) - Method in interface com.linkedin.alpini.cli.CLIParser
 
showUsage(String) - Method in class com.linkedin.alpini.cli.CLIArgumentParser
Display an error message plus command line usage information.
showUsage(String) - Method in interface com.linkedin.alpini.cli.CLIParser
 
shutdown() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in interface com.linkedin.alpini.base.pool.AsyncPool.LifeCycle
 
shutdown() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
Starts the shutdown process.
shutdown() - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
Starts the shutdown process.
shutdown() - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
shutdown() - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableScheduledExecutorServiceImpl
 
shutdown() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Starts the shutdown process.
shutdown() - Method in interface com.linkedin.alpini.base.registry.Shutdownable
Starts the shutdown process.
shutdown() - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
 
shutdown() - Method in class com.linkedin.alpini.netty4.handlers.VIPRequestHandler
 
shutdown() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
shutdown() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
shutdown() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
 
shutdown() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
Starts the shutdown process.
shutdown() - Method in class com.linkedin.venice.d2.D2HealthChecker
 
shutdown() - Method in class com.linkedin.venice.d2.D2ServerManager
 
shutdown() - Method in class com.linkedin.venice.server.VeniceServer
Method which closes VeniceServer, shuts down its resources, and exits the JVM.
shutdown() - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
 
shutdown(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This method is a blocking call to wait for StoreIngestionTask for fully shutdown in the given time.
SHUTDOWN - com.linkedin.alpini.netty4.handlers.VIPRequestHandler.State
Shutdown has been requested.
SHUTDOWN_COMPONENT - com.linkedin.venice.ingestion.protocol.enums.IngestionAction
 
SHUTDOWN_INGESTION_TASK - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
SHUTDOWN_THREAD_PREFIX - Static variable in class com.linkedin.alpini.base.registry.ResourceRegistry
 
Shutdownable - Interface in com.linkedin.alpini.base.registry
 
ShutdownableChannelGroup - Class in com.linkedin.alpini.netty4.handlers
 
ShutdownableChannelGroup(EventExecutor) - Constructor for class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
Creates a new group with a generated name and the provided EventExecutor to notify the ChannelGroupFutures.
ShutdownableChannelGroup(EventExecutor, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
Creates a new group with a generated name and the provided EventExecutor to notify the ChannelGroupFutures.
ShutdownableChannelGroup(String, EventExecutor) - Constructor for class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
Creates a new group with the specified name and EventExecutor to notify the ChannelGroupFutures.
ShutdownableChannelGroup(String, EventExecutor, boolean) - Constructor for class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
Creates a new group with the specified name and EventExecutor to notify the ChannelGroupFutures.
ShutdownableEventLoopGroup<E extends io.netty.channel.EventLoopGroup> - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/30/17.
ShutdownableEventLoopGroup(E) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
ShutdownableExecutors - Interface in com.linkedin.alpini.base.registry
An Executor factory to be used with ResourceRegistry instead of using Executors
Example:
ShutdownableExecutorService - Interface in com.linkedin.alpini.base.registry
An ExecutorService interface which also extends the Shutdownable interface.
ShutdownableExecutorServiceImpl<E extends ExecutorService> - Class in com.linkedin.alpini.base.registry.impl
 
ShutdownableExecutorServiceImpl(E) - Constructor for class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
ShutdownableHashedWheelTimer - Class in com.linkedin.alpini.netty4.misc
 
ShutdownableHashedWheelTimer() - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
Creates a new timer with the default thread factory (Executors.defaultThreadFactory()), default tick duration, and default number of ticks per wheel.
ShutdownableHashedWheelTimer(long, TimeUnit) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
Creates a new timer with the default thread factory (Executors.defaultThreadFactory()) and default number of ticks per wheel.
ShutdownableHashedWheelTimer(long, TimeUnit, int) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
Creates a new timer with the default thread factory (Executors.defaultThreadFactory()).
ShutdownableHashedWheelTimer(ThreadFactory) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
Creates a new timer with the default tick duration and default number of ticks per wheel.
ShutdownableHashedWheelTimer(ThreadFactory, long, TimeUnit) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
Creates a new timer with the default number of ticks per wheel.
ShutdownableHashedWheelTimer(ThreadFactory, long, TimeUnit, int) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
Creates a new timer.
ShutdownableHashedWheelTimer(ThreadFactory, long, TimeUnit, int, boolean) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
Creates a new timer.
ShutdownableNioEventLoopGroup - Class in com.linkedin.alpini.netty4.misc
 
ShutdownableNioEventLoopGroup() - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
Create a new instance using the default number of threads, the default ThreadFactory and the SelectorProvider which is returned by SelectorProvider.provider().
ShutdownableNioEventLoopGroup(int) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
Create a new instance using the specified number of threads, ThreadFactory and the SelectorProvider which is returned by SelectorProvider.provider().
ShutdownableNioEventLoopGroup(int, Executor) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
 
ShutdownableNioEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectorProvider, SelectStrategyFactory) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
 
ShutdownableNioEventLoopGroup(int, Executor, EventExecutorChooserFactory, SelectorProvider, SelectStrategyFactory, RejectedExecutionHandler) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
 
ShutdownableNioEventLoopGroup(int, Executor, SelectorProvider) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
 
ShutdownableNioEventLoopGroup(int, Executor, SelectorProvider, SelectStrategyFactory) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
 
ShutdownableNioEventLoopGroup(int, ThreadFactory) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
Create a new instance using the specified number of threads, the given ThreadFactory and the SelectorProvider which is returned by SelectorProvider.provider().
ShutdownableNioEventLoopGroup(int, ThreadFactory, SelectorProvider) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
Create a new instance using the specified number of threads, the given ThreadFactory and the given SelectorProvider.
ShutdownableNioEventLoopGroup(int, ThreadFactory, SelectorProvider, SelectStrategyFactory) - Constructor for class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
 
ShutdownableResource - Interface in com.linkedin.alpini.base.registry
 
ShutdownableScheduledExecutorService - Interface in com.linkedin.alpini.base.registry
A ScheduledExecutorService interface which also extends the Shutdownable interface.
ShutdownableScheduledExecutorServiceImpl<E extends ScheduledExecutorService> - Class in com.linkedin.alpini.base.registry.impl
 
ShutdownableScheduledExecutorServiceImpl(E) - Constructor for class com.linkedin.alpini.base.registry.impl.ShutdownableScheduledExecutorServiceImpl
 
shutdownAndAwaitTermination() - Method in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
shutdownClient(D2Client) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
shutdownClient(D2Client, long) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
ShutdownException() - Constructor for exception com.linkedin.alpini.base.pool.impl.AsyncPoolImpl.ShutdownException
 
shutdownExecutor(ExecutorService) - Static method in class com.linkedin.venice.utils.TestUtils
 
shutdownExecutor(ExecutorService, long, TimeUnit) - Static method in class com.linkedin.venice.utils.TestUtils
 
shutDownExecutor() - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
shutDownExecutor() - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelDualPoolFactory
 
shutdownForkedProcessComponent(IngestionComponentType) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
shutdownGracefully() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
shutdownGracefully(long, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
shutdownGracefully(long, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
shutdownGracefully(long, long, TimeUnit) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
shutdownIngestionTask(String) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
shutdownIngestionTask(String) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
 
shutdownIngestionTask(String) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
shutdownIngestionTask(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
shutdownNow() - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
shutdownNow() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Attempts to stop all actively executing tasks, halts the processing of waiting tasks, and returns a list of the tasks that were awaiting execution.
shutdownNow() - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
shutdownNow() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
shutdownNow(Object) - Static method in interface com.linkedin.alpini.base.registry.Shutdownable
 
shutdownPool() - Method in interface com.linkedin.alpini.base.pool.AsyncPool
 
shutdownPool() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
shutdownResourceRegistry() - Method in class com.linkedin.alpini.base.test.ResourceRegistryTestBase
 
shutdownStoreIngestionTask(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
This method closes the specified StoreIngestionTask and wait for up to 10 seconds for fully shutdown.
shutdownSynchronously() - Method in interface com.linkedin.alpini.base.registry.SyncShutdownable
Shutdown synchronously
shutdownThread(Thread) - Static method in class com.linkedin.venice.utils.TestUtils
 
shutdownThread(Thread, long, TimeUnit) - Static method in class com.linkedin.venice.utils.TestUtils
 
signalShutdownInitiated() - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
Called by the Runnable to indicate that shutdown has started.
SIMPLE_USER_WITH_DEFAULT_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
SimpleChannelInitializer<C extends io.netty.channel.Channel> - Class in com.linkedin.alpini.netty4.handlers
Created by acurtis on 4/27/18.
SimpleChannelInitializer() - Constructor for class com.linkedin.alpini.netty4.handlers.SimpleChannelInitializer
 
SimpleChannelPoolManagerImpl - Class in com.linkedin.alpini.netty4.pool
In order to simplify the implementation of this ChannelPoolManager, this implementation requires that SimpleChannelPoolManagerImpl.open(String) is called to create the hostNameAndPort instead of lazily creating them upon first reference.
SimpleChannelPoolManagerImpl(E, ChannelPoolFactory) - Constructor for class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
SimpleJsonMapper - Enum in com.linkedin.alpini.base.misc
A VERY simple JSON mapper.
SimplePartitioner - Class in com.linkedin.venice.unit.kafka
This VenicePartitioner implementation takes the first byte of the key, and computes the partition as such: firstByte % numPartitions It is meant to be used in tests where we want to control the partition that a key belongs to, but without needing to work out a proper input that yields the desired partition when hashed by the DefaultVenicePartitioner.
SimplePartitioner() - Constructor for class com.linkedin.venice.unit.kafka.SimplePartitioner
 
SimplePartitioner(VeniceProperties) - Constructor for class com.linkedin.venice.unit.kafka.SimplePartitioner
 
SimplePartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.unit.kafka.SimplePartitioner
 
SimplePubSubProduceResultImpl - Class in com.linkedin.venice.pubsub.adapter
A simple implementation of PubSubProduceResult interface for testing purposes.
SimplePubSubProduceResultImpl(String, int, long, int) - Constructor for class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
 
SimpleQueue<T> - Interface in com.linkedin.alpini.base.queuing
Simplified Queue Interface that supports basic operations like add(), poll() etc akin to the operations on Queue.
SimpleRatioStat(Rate, Rate, String) - Constructor for class com.linkedin.venice.stats.TehutiUtils.SimpleRatioStat
 
SimpleStringSerializer - Class in com.linkedin.venice.meta
 
SimpleStringSerializer() - Constructor for class com.linkedin.venice.meta.SimpleStringSerializer
 
simpleTask() - Method in class com.linkedin.alpini.netty4.handlers.Http2PingResponseHandler
 
SINGLE_GET - com.linkedin.venice.read.RequestType
 
SINGLE_GET_CLIENT_REQUEST_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Client request for single-get v1.
SINGLE_GET_ROUTER_CACHE_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
SINGLE_GET_ROUTER_REQUEST_V1 - com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Router request for single-get v1.
SINGLE_POOL_STRATEGY - com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory.LeaderFollowerThreadPoolStrategy
 
SingleGetChunkingAdapter - Class in com.linkedin.davinci.storage.chunking
Single get chunking adapter
singleGetRouterCacheEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
singleGetRouterCacheEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
SingleThreadEventLoopGroup - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/30/17.
SingleThreadEventLoopGroup(EventLoop) - Constructor for class com.linkedin.alpini.netty4.misc.SingleThreadEventLoopGroup
 
SingleThreadEventLoopGroupSupplier - Interface in com.linkedin.alpini.netty4.misc
Created by acurtis on 3/30/17.
singleThreadGroup() - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
Return a EventLoopGroup which represents a single thread.
singleThreadGroup() - Method in interface com.linkedin.alpini.netty4.misc.SingleThreadEventLoopGroupSupplier
 
singleThreadGroup(EventLoop) - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
Return a EventLoopGroup which represents a single thread.
singleThreadGroup(EventLoop) - Method in interface com.linkedin.alpini.netty4.misc.SingleThreadEventLoopGroupSupplier
 
singleton(E) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
SINGLETON - com.linkedin.alpini.base.concurrency.Executors
 
SINGLETON - com.linkedin.alpini.base.misc.CollectionUtil
 
SINGLETON - com.linkedin.alpini.base.misc.DateUtils
 
SINGLETON - com.linkedin.alpini.base.misc.ExceptionUtil
 
SINGLETON - com.linkedin.alpini.base.misc.HeaderNames
 
SINGLETON - com.linkedin.alpini.base.misc.HeaderUtils
 
SINGLETON - com.linkedin.alpini.base.misc.JDBCUtils
 
SINGLETON - com.linkedin.alpini.base.misc.Preconditions
 
SINGLETON - com.linkedin.alpini.base.misc.ProcessUtil
 
SINGLETON - com.linkedin.alpini.base.misc.SimpleJsonMapper
 
SINGLETON - com.linkedin.alpini.base.misc.Time
 
SINGLETON - com.linkedin.alpini.base.misc.TimeFormat
 
SINGLETON - com.linkedin.alpini.base.misc.URLCodec
 
SINGLETON - com.linkedin.alpini.base.test.TestUtil
 
SINGLETON - com.linkedin.alpini.io.IOUtils
 
SINGLETON - com.linkedin.alpini.netty4.misc.AsciiStringURLCodec
 
SINGLETON - com.linkedin.alpini.netty4.misc.HttpUtils
 
SINGLETON - Static variable in class com.linkedin.venice.pubsub.api.EmptyPubSubMessageHeaders
 
size - Variable in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
The number of bytes of the entire value, once all chunks are assembled.
size() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
size() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
size() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Returns the number of elements in this list.
size() - Method in interface com.linkedin.alpini.base.pool.AsyncPool
 
size() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
size() - Method in class com.linkedin.alpini.base.queuing.QOSBasedMultiQueue
size() - Method in class com.linkedin.alpini.base.queuing.QOSBasedQueue
 
size() - Method in class com.linkedin.alpini.base.queuing.QOSFCFSQueue
 
size() - Method in interface com.linkedin.alpini.base.queuing.SimpleQueue
 
size() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantiles
 
size() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
size() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
size() - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
 
size() - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
Returns the approximate number of entries in this cache.
size() - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns the number of key-value mappings in this map.
size() - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
size() - Method in class com.linkedin.venice.utils.SharedObjectFactory
 
size() - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Get the number of elements in this queue added via one of the AbstractCoalescingBufferQueue10294.add(ByteBuf) methods.
SIZE_OF_BOOLEAN - Static variable in class com.linkedin.venice.utils.ByteUtils
 
SIZE_OF_INT - Static variable in class com.linkedin.venice.utils.ByteUtils
 
SIZE_OF_LONG - Static variable in class com.linkedin.venice.utils.ByteUtils
 
SIZE_OF_SHORT - Static variable in class com.linkedin.venice.utils.ByteUtils
 
skip(long) - Method in class com.linkedin.alpini.io.ZeroInputStream
 
SKIP_ADMIN - com.linkedin.venice.Command
 
SKIP_ADMIN - com.linkedin.venice.controllerapi.ControllerRoute
 
SKIP_CONTROL_CHARS - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
SKIP_DIV - com.linkedin.venice.Arg
 
SKIP_DIV - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
SKIP_LAST_STORE_CREATION - com.linkedin.venice.Arg
 
SKIP_LIST - com.linkedin.alpini.base.monitoring.CallTrackerImpl.Mode
 
skipAdminMessage(Admin) - Method in class com.linkedin.venice.controller.server.SkipAdminRoute
 
skipAdminMessage(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
skipAdminMessage(String, long, boolean) - Method in interface com.linkedin.venice.controller.Admin
The admin consumption task tries to deal with failures to process an admin message by retrying.
skipAdminMessage(String, long, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
skipAdminMessage(String, long, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
SkipAdminRoute - Class in com.linkedin.venice.controller.server
 
SkipAdminRoute(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.SkipAdminRoute
 
skipArray() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
skipBytes() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
skipFixed(int) - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
skipKafkaMessage() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
skipMap() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
skipNulls() - Method in class com.linkedin.alpini.base.misc.Joiner
 
SKIPPED_MESSAGE - com.linkedin.davinci.kafka.consumer.StoreIngestionTask.DelegateConsumerRecordResult
The consumer record is skipped.
skipRmdRecord(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
When schemeId is negative, it indicates a chunked record.
skipRmdRecord(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
Define how records could be skipped if certain conditions are met.
skipString() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
 
sleep(long) - Static method in enum com.linkedin.alpini.base.misc.Time
 
sleep(long) - Static method in class com.linkedin.venice.utils.LatencyUtils
Sleep until number of milliseconds have passed, or the operation is interrupted.
sleep(long) - Method in class com.linkedin.venice.utils.MockCircularTime
 
sleep(long) - Method in class com.linkedin.venice.utils.SystemTime
 
sleep(long) - Method in class com.linkedin.venice.utils.TestMockTime
 
sleep(long) - Method in interface com.linkedin.venice.utils.Time
 
sleep(long) - Static method in class com.linkedin.venice.utils.Utils
Sleep until number of milliseconds have passed, or the operation is interrupted.
sleep(long, int) - Static method in enum com.linkedin.alpini.base.misc.Time
 
SLEEP_TIME_MS_WHEN_TOPIC_MISSING - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
sleepInterruptable(long) - Static method in enum com.linkedin.alpini.base.misc.Time
 
sleepIntervalBetweenTopicListFetchMs - Variable in class com.linkedin.venice.controller.kafka.TopicCleanupService
 
sleepUninterruptably(long) - Static method in enum com.linkedin.alpini.base.misc.Time
 
slice(ByteBuf, int, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
SLICE - com.linkedin.alpini.netty4.misc.NettyUtils.ReadMode
 
slice0(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
slice0(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
SlowFieldAccessor<T,​V> - Class in com.linkedin.alpini.base.misc
Field accessor using Reflection.
SlowFieldAccessor() - Constructor for class com.linkedin.alpini.base.misc.SlowFieldAccessor
 
SlowFieldAccessorHelper - Class in com.linkedin.alpini.base.misc
Helper class for the SlowFieldAccessor implementation.
SlowFieldAccessorHelper() - Constructor for class com.linkedin.alpini.base.misc.SlowFieldAccessorHelper
 
SMART_RETRY_ABORTED_BY_DELAY_CONSTRAINT - com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
 
SMART_RETRY_ABORTED_BY_MAX_RETRY_ROUTE_LIMIT - com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
 
SMART_RETRY_ABORTED_BY_SLOW_ROUTE - com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
 
SNAPPY - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
SNAPPY_ENCODING - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
SNAPPY_FRAMED - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
SNAPPY_FRAMED_ENCODING - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
SnappyDecoder - Class in com.linkedin.alpini.netty4.compression
 
SnappyDecoder() - Constructor for class com.linkedin.alpini.netty4.compression.SnappyDecoder
 
SnappyEncoder - Class in com.linkedin.alpini.netty4.compression
 
SnappyEncoder() - Constructor for class com.linkedin.alpini.netty4.compression.SnappyEncoder
 
socketChannel() - Method in enum com.linkedin.alpini.netty4.misc.NettyUtils.Mode
 
socketChannel() - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
 
SoftThreadLocal<T> - Class in com.linkedin.alpini.base.misc
This class provides thread-local variables with SoftReference semantics.
SoftThreadLocal() - Constructor for class com.linkedin.alpini.base.misc.SoftThreadLocal
 
sort(Comparator<? super E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
SORT_KEY - Static variable in class io.netty.bootstrap.ResolveAllBootstrap
 
SortBasedCollectionFieldOpHandler - Class in com.linkedin.davinci.schema.merge
 
SortBasedCollectionFieldOpHandler(AvroCollectionElementComparator) - Constructor for class com.linkedin.davinci.schema.merge.SortBasedCollectionFieldOpHandler
 
sorted - Variable in class com.linkedin.venice.kafka.protocol.StartOfPush
Whether the messages inside current topic partition between 'StartOfPush' control message and 'EndOfPush' control message is lexicographically sorted by key bytes
sorted - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Whether the messages inside the current store-version, between the 'StartOfPush' and 'EndOfPush' control messages, are lexicographically sorted by key bytes.
SORTED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SORTED_INPUT_DRAINER_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
 
sortedStoreBufferServiceDelegate - Variable in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
sortResolvedAddress(Comparator<SocketAddress>) - Method in class io.netty.bootstrap.ResolveAllBootstrap
 
SOURCE_ETL - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SOURCE_FABRIC - com.linkedin.venice.Arg
 
SOURCE_FABRIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
For Blueshift data copy over across fabrics.
SOURCE_FABRIC_VERSION_INCLUDED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
Boolean flag to indicate whether the Version needed for data recover from the source fabric is included in the request body as byte array or not.
SOURCE_GRID_FABRIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
SOURCE_GRID_FABRIC - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
An identifier of the data center which is used to determine the Kafka URL and child controllers that push jobs communicate with
SOURCE_KAFKA - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Configs used to enable Kafka Input.
sourceCluster - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
The source Venice cluster of the store.
sourceGridFabric - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
sourceKafkaCluster - Variable in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Kafka bootstrap servers URL of the cluster where the source buffer exists.
sourceKafkaInputVersionInfo - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
sourceKafkaServers - Variable in class com.linkedin.venice.kafka.protocol.TopicSwitch
A list of Kafka bootstrap servers URLs where the new source topic exists; currently there will be only one URL in the list, but the list opens up the possibility for leader to consume from different fabrics in active-active replication mode.
sourceOffsets - Variable in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Array of offsets from the real-time buffer topic at which the Buffer Replay Service started replaying data.
sourceTopicName - Variable in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Name of the source buffer topic.
sourceTopicName - Variable in class com.linkedin.venice.kafka.protocol.TopicSwitch
Name of new the source topic.
sourceVersionChunkingEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
sourceVersionCompressionStrategy - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
SPARK_APP_NAME_CONFIG - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
SPARK_CASE_SENSITIVE_CONFIG - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
SPARK_CLUSTER_CONFIG - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
SPARK_DATA_WRITER_CONF_PREFIX - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
Configs with this prefix will be set when building the data writer spark job and passed as job properties.
SPARK_LEADER_CONFIG - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
SPARK_SESSION_CONF_PREFIX - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
Configs with this prefix will be set when building the spark session.
SparkConstants - Class in com.linkedin.venice.hadoop.spark
 
SparkConstants() - Constructor for class com.linkedin.venice.hadoop.spark.SparkConstants
 
SparkDataWriterTaskTracker - Class in com.linkedin.venice.hadoop.spark.datawriter.task
 
SparkDataWriterTaskTracker(DataWriterAccumulators) - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
SparkEngineTaskConfigProvider - Class in com.linkedin.venice.hadoop.spark.engine
 
SparkEngineTaskConfigProvider(Properties) - Constructor for class com.linkedin.venice.hadoop.spark.engine.SparkEngineTaskConfigProvider
 
SparkInputRecordProcessor - Class in com.linkedin.venice.hadoop.spark.datawriter.recordprocessor
An implementation of AbstractInputRecordProcessor for Spark that processes input records from the dataframe and emits an Iterator of Row with DEFAULT_SCHEMA as the schema.
SparkInputRecordProcessor(Properties, DataWriterAccumulators) - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.recordprocessor.SparkInputRecordProcessor
 
SparkInputRecordProcessorFactory - Class in com.linkedin.venice.hadoop.spark.datawriter.recordprocessor
A Factory class to create individual SparkInputRecordProcessor for processing records in a Spark Dataframe.
SparkInputRecordProcessorFactory(Broadcast<Properties>, DataWriterAccumulators) - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.recordprocessor.SparkInputRecordProcessorFactory
 
SparkPartitionUtils - Class in com.linkedin.venice.hadoop.spark.utils
Spark partitioning functionality in Dataframe and Dataset APIs is not very flexible.
SparkPartitionWriter - Class in com.linkedin.venice.hadoop.spark.datawriter.writer
 
SparkPartitionWriter(Properties, DataWriterAccumulators) - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.writer.SparkPartitionWriter
 
SparkPartitionWriterFactory - Class in com.linkedin.venice.hadoop.spark.datawriter.writer
 
SparkPartitionWriterFactory(Broadcast<Properties>, DataWriterAccumulators) - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.writer.SparkPartitionWriterFactory
 
SparkScalaUtils - Class in com.linkedin.venice.hadoop.spark.utils
Utility methods for restricting Scala-ism in Spark code in a single class.
SparkServerStats - Class in com.linkedin.venice.controller.stats
 
SparkServerStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.SparkServerStats
 
SparseConcurrentList<E> - Class in com.linkedin.venice.utils
A List implementation with some usability improvements around resizing.
SparseConcurrentList() - Constructor for class com.linkedin.venice.utils.SparseConcurrentList
 
SparseConcurrentListWithOffset<E> - Class in com.linkedin.venice.utils
A very simple subclass of SparseConcurrentList which adds some immutable offset to all index.
SparseConcurrentListWithOffset(int) - Constructor for class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
SpecificRecordChunkingAdapter<V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.davinci.storage.chunking
 
SpecificRecordChunkingAdapter() - Constructor for class com.linkedin.davinci.storage.chunking.SpecificRecordChunkingAdapter
 
SpecificRetriableStoreClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.client.store
This class is necessary because Venice needs to maintain a separate interface: AvroSpecificStoreClient.
SpecificRetriableStoreClient(SpecificStatTrackingStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.client.store.SpecificRetriableStoreClient
 
SpecificStatTrackingStoreClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.client.store
This class is necessary because Venice needs to maintain a separate interface: AvroSpecificStoreClient.
SpecificStatTrackingStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.client.store.SpecificStatTrackingStoreClient
 
split(char) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Splits the specified String with the specified delimiter..
split(String, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Splits this string using the supplied regular expression expr.
split(Pattern) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
split(Pattern, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
split(Set<K>, int) - Static method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
splitChunkedKey(byte[], ChunkKeyValueTransformer.KeyType) - Method in interface com.linkedin.venice.chunking.ChunkKeyValueTransformer
 
splitChunkedKey(byte[], ChunkKeyValueTransformer.KeyType) - Method in class com.linkedin.venice.chunking.ChunkKeyValueTransformerImpl
 
spliterator() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
spliterator(Iterator<T>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
sprayAllPartitionsTriggeredCount - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
squaredL2Norm(List<Float>) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
srcClusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
srcClusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
SSL_CONFIG_PATH - com.linkedin.venice.Arg
 
SSL_CONFIGURATOR_CLASS_CONFIG - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SSL_ENABLED - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_FACTORY_CLASS_NAME - Static variable in class com.linkedin.venice.CommonConfigKeys
This config defines the class name of the SSL factory.
SSL_KAFKA_BOOTSTRAP_SERVERS - Static variable in class com.linkedin.venice.ConfigKeys
 
SSL_KAFKA_BOOTSTRAP_SERVERS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
 
SSL_KEY_PASSWORD - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_KEY_PASSWORD_PROPERTY_NAME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SSL_KEY_STORE_PASSWORD_PROPERTY_NAME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SSL_KEY_STORE_PROPERTY_NAME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SSL_KEYMANAGER_ALGORITHM - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_KEYSTORE_LOCATION - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_KEYSTORE_PASSWORD - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_KEYSTORE_TYPE - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_NEEDS_CLIENT_CERT - Static variable in class com.linkedin.venice.CommonConfigKeys
This config mainly control the SSL behavior inside AdminSparkServer.
SSL_PACKET_SIZE - Static variable in class com.linkedin.alpini.netty4.handlers.OutboundByteBufAggregator
 
SSL_PREFIX - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SSL_SECURE_RANDOM_IMPLEMENTATION - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_TO_KAFKA_LEGACY - Static variable in class com.linkedin.venice.ConfigKeys
Deprecated.
SSL_TO_KAFKA_LEGACY - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
SSL_TO_STORAGE_NODES - Static variable in class com.linkedin.venice.ConfigKeys
 
SSL_TRUST_STORE_PROPERTY_NAME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SSL_TRUSTMANAGER_ALGORITHM - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_TRUSTSTORE_LOCATION - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_TRUSTSTORE_PASSWORD - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SSL_TRUSTSTORE_TYPE - Static variable in class com.linkedin.venice.CommonConfigKeys
 
SslClientInitializer - Class in com.linkedin.alpini.netty4.ssl
Created by acurtis on 9/7/17.
SslClientInitializer(SSLEngineFactory) - Constructor for class com.linkedin.alpini.netty4.ssl.SslClientInitializer
 
SslClientInitializer(SSLEngineFactory, boolean) - Constructor for class com.linkedin.alpini.netty4.ssl.SslClientInitializer
 
SSLConfig - Class in com.linkedin.venice.security
 
SSLConfig - Class in com.linkedin.venice
 
SSLConfig() - Constructor for class com.linkedin.venice.security.SSLConfig
 
SSLConfig(VeniceProperties) - Constructor for class com.linkedin.venice.SSLConfig
 
SSLConfig.ConfigHelper - Class in com.linkedin.venice.security
 
SSLConfig.ConfigHelper.MissingConfigParameterException - Exception in com.linkedin.venice.security
 
SSLConfigurator - Interface in com.linkedin.venice.hadoop.ssl
 
SSLContextBuilder - Class in com.linkedin.alpini.io.ssl
Builds a new instance of SSLContext object from given key store and trust store parameters.
SSLContextBuilder - Class in com.linkedin.alpini.netty4.http2
Created by acurtis on 4/19/18.
SSLContextBuilder() - Constructor for class com.linkedin.alpini.io.ssl.SSLContextBuilder
 
sslEnabled(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
 
SSLEngineFactory - Interface in com.linkedin.alpini.netty4.ssl
Factory interface to create SSLEngine and get SSLSessionContext objects for Netty4 pipelines
SSLEngineFactoryImpl - Class in com.linkedin.alpini.netty4.ssl
 
SSLEngineFactoryImpl(SSLEngineFactoryImpl.Config) - Constructor for class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
 
SSLEngineFactoryImpl.Config - Class in com.linkedin.alpini.netty4.ssl
 
SslFactory - Interface in com.linkedin.alpini.base.ssl
SSL Factory interface to get common SSL objects.
SSLFactory - Interface in com.linkedin.venice.security
Venice SSL Factory interface.
sslHandshakeComplete(ChannelHandlerContext, SslHandshakeCompletionEvent) - Method in class com.linkedin.alpini.netty4.ssl.SecureClientHandler
 
SslInitializer - Class in com.linkedin.alpini.netty4.ssl
Created by acurtis on 9/7/17.
SslInitializer(SslFactory, boolean) - Constructor for class com.linkedin.alpini.netty4.ssl.SslInitializer
 
SslInitializer(SslFactory, boolean, ChannelHandler) - Constructor for class com.linkedin.alpini.netty4.ssl.SslInitializer
 
SslInitializer(SslFactory, ChannelHandler) - Constructor for class com.linkedin.alpini.netty4.ssl.SslInitializer
 
SslInitializer(SSLEngineFactory, boolean, ChannelHandler) - Constructor for class com.linkedin.alpini.netty4.ssl.SslInitializer
 
SslInitializer(SSLEngineFactory, ChannelHandler) - Constructor for class com.linkedin.alpini.netty4.ssl.SslInitializer
 
sslToKafka - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
SslUtils - Class in com.linkedin.venice.utils
 
SslUtils() - Constructor for class com.linkedin.venice.utils.SslUtils
 
SslUtils.VeniceTlsConfiguration - Class in com.linkedin.venice.utils
This class is used to configure TLS for Venice components in integration tests.
SslUtils.VeniceTlsConfiguration.Builder - Class in com.linkedin.venice.utils
 
stackTraceToString(Throwable) - Static method in class com.linkedin.venice.utils.ExceptionUtils
 
StaleConnectionHandler - Class in com.linkedin.alpini.netty4.handlers
This handler closes the connection when a ReadTimeoutException occurs.
StaleConnectionHandler() - Constructor for class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
Create an EspressoIdleConnectionHandler which will close idle connections (detected by a separate IdleStateHandler added to the pipeline).
StaleConnectionHandler(long, long, TimeUnit) - Constructor for class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
Deprecated.
StaleVersionReason - Enum in com.linkedin.venice.router.stats
This enum is used to denote why a particular store version was found to be stale
StaleVersionStats - Class in com.linkedin.venice.router.stats
 
StaleVersionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.router.stats.StaleVersionStats
 
STANDBY - com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
This partition is a follower.
STANDBY - com.linkedin.venice.helix.HelixState
 
STANDBY_STATE - Static variable in enum com.linkedin.venice.helix.HelixState
 
STANDBY_TO_LEADER - com.linkedin.davinci.kafka.consumer.ConsumerActionType
 
start() - Method in interface com.linkedin.alpini.base.pool.AsyncPool
 
start() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
start() - Method in class com.linkedin.alpini.io.ExternalCommand
After creating the command, you have to start it...
start() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
start() - Method in class com.linkedin.alpini.netty4.handlers.VIPRequestHandler
 
start() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
start() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
start() - Method in interface com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumer
 
start() - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
start() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
start() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
 
start() - Method in class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
 
start() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
start() - Method in class com.linkedin.venice.controller.VeniceController
Causes venice controller and its associated services to begin execution.
start() - Method in class com.linkedin.venice.d2.D2HealthChecker
 
start() - Method in class com.linkedin.venice.d2.D2ServerManager
 
start() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
start() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
start() - Method in class com.linkedin.venice.fastclient.meta.DaVinciClientBasedMetadata
Deprecated.
 
start() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
 
start() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
start() - Method in class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
start() - Method in class com.linkedin.venice.grpc.VeniceGrpcServer
 
start() - Method in class com.linkedin.venice.kafka.validation.Segment
 
start() - Method in class com.linkedin.venice.pushmonitor.PushStatusCollector
 
start() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
 
start() - Method in class com.linkedin.venice.pushmonitor.RouterBasedPushMonitor
 
start() - Method in class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
 
start() - Method in class com.linkedin.venice.router.httpclient.HttpClient5StorageNodeClient
 
start() - Method in interface com.linkedin.venice.router.httpclient.StorageNodeClient
Start the client and prepare the required resources.
start() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
start() - Method in class com.linkedin.venice.server.VeniceServer
Method which starts the services instantiate earlier.
start() - Method in class com.linkedin.venice.service.AbstractVeniceService
 
start(String...) - Static method in class com.linkedin.alpini.io.ExternalCommand
Creates an external process from the command.
start(String, int) - Method in class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSender
 
start(String, int) - Method in interface com.linkedin.venice.hadoop.heartbeat.PushJobHeartbeatSender
 
start(SocketAddress) - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
 
start(SocketAddress) - Method in interface com.linkedin.alpini.router.impl.Router
 
start(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumer
Start performs both a topic subscription and catch up.
START_CONSUMPTION - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
START_DATA_WRITER_JOB - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
START_DATE - com.linkedin.venice.Arg
 
START_FABRIC_BUILDOUT - com.linkedin.venice.Command
 
START_JOB_STATUS_POLLING - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
START_OF_BUFFER_REPLAY - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
Deprecated.
START_OF_BUFFER_REPLAY_RECEIVED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
Deprecated.
START_OF_BUFFER_REPLAY_RECEIVED - com.linkedin.venice.pushmonitor.ExecutionStatus
Deprecated.
START_OF_BUFFER_REPLAY_RECEIVED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
START_OF_INCREMENTAL_PUSH - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
START_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
START_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.pushmonitor.ExecutionStatus
An incremental push job/task is started
START_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
START_OF_INCREMENTAL_PUSH_RECEIVED - com.linkedin.venice.status.PushJobDetailsStatus
 
START_OF_PUSH - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
START_OF_SEGMENT - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
START_VALIDATE_SCHEMA_AND_BUILD_DICT_MAP_JOB - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
startCall() - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
startCall(long) - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
startCall(long) - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
startCall(long) - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
startClient(D2Client) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
startClient(D2Client, long) - Static method in class com.linkedin.venice.D2.D2ClientUtils
 
startConsumingAsLeader(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
startConsumingAsLeader(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
startConsumingAsLeader(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
startConsumingAsLeaderInTransitionFromStandby(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
startConsumption(VeniceStoreVersionConfig, int) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
 
startConsumption(VeniceStoreVersionConfig, int) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
 
startConsumption(VeniceStoreVersionConfig, int, Optional<LeaderFollowerStateType>) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
startConsumption(VeniceStoreVersionConfig, int, Optional<LeaderFollowerStateType>) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
 
startConsumption(VeniceStoreVersionConfig, int, Optional<LeaderFollowerStateType>) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
startConsumption(VeniceStoreVersionConfig, int, Optional<LeaderFollowerStateType>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
Starts consuming messages from Kafka Partition corresponding to Venice Partition.
startConsumption(VeniceStoreVersionConfig, int, Optional<LeaderFollowerStateType>) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Starts consuming messages from Kafka Partition corresponding to Venice Partition.
startConsumption(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
startConsumptionIntoDataReceiver(PubSubTopicPartition, long, ConsumedDataReceiver<List<PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>>>) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
startConsumptionIntoDataReceiver(PubSubTopicPartition, long, ConsumedDataReceiver<List<PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>>>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
startConsumptionIntoDataReceiver(PubSubTopicPartition, long, ConsumedDataReceiver<List<PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>>>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
started(String, int) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Consumption is started for a store and partition
started(String, int, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
started(String, int, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
started(String, int, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
started(String, int, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
started(String, int, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
STARTED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
STARTED - com.linkedin.venice.meta.VersionStatus
 
STARTED - com.linkedin.venice.pushmonitor.ExecutionStatus
Job/Task is started and start consuming data from Kafka
STARTED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
STARTED - com.linkedin.venice.service.AbstractVeniceService.ServiceState
 
STARTED - com.linkedin.venice.status.PushJobDetailsStatus
 
startErrorPartitionResetTask() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
Cause ErrorPartitionResetTask service to begin executing.
startForkedIngestionProcess(VeniceConfigLoader) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
STARTING - com.linkedin.venice.service.AbstractVeniceService.ServiceState
 
STARTING_OFFSET - com.linkedin.venice.Arg
 
startInner() - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
startInner() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
startInner() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
startInner() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
startInner() - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
IMPORTANT: All newly created KafkaConsumerService are already started in AggKafkaConsumerService.createKafkaConsumerService(Properties), if this is no longer the case in future, make sure to update the startInner logic here.
startInner() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
startInner() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
startInner() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
Starts the Kafka consumption tasks for already subscribed partitions.
startInner() - Method in class com.linkedin.davinci.kafka.consumer.RemoteIngestionRepairService
 
startInner() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
startInner() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
startInner() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
startInner() - Method in class com.linkedin.davinci.storage.DiskHealthCheckService
 
startInner() - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
startInner() - Method in class com.linkedin.davinci.storage.StorageService
 
startInner() - Method in class com.linkedin.venice.cleaner.BackupVersionOptimizationService
 
startInner() - Method in class com.linkedin.venice.cleaner.LeakedResourceCleaner
 
startInner() - Method in class com.linkedin.venice.controller.DisabledPartitionEnablerService
 
startInner() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
 
startInner() - Method in class com.linkedin.venice.controller.kafka.TopicCleanupService
 
startInner() - Method in class com.linkedin.venice.controller.server.AdminSparkServer
 
startInner() - Method in class com.linkedin.venice.controller.StoreBackupVersionCleanupService
 
startInner() - Method in class com.linkedin.venice.controller.StoreGraveyardCleanupService
 
startInner() - Method in class com.linkedin.venice.controller.systemstore.SystemStoreRepairService
 
startInner() - Method in class com.linkedin.venice.controller.UnusedValueSchemaCleanupService
 
startInner() - Method in class com.linkedin.venice.controller.VeniceControllerService
Causes VeniceControllerService to begin execution.
startInner() - Method in class com.linkedin.venice.listener.ListenerService
 
startInner() - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
startInner() - Method in class com.linkedin.venice.pushmonitor.LeakedPushStatusCleanUpService
 
startInner() - Method in class com.linkedin.venice.router.api.DictionaryRetrievalService
 
startInner() - Method in class com.linkedin.venice.router.api.RouterHeartbeat
 
startInner() - Method in class com.linkedin.venice.router.RouterServer
 
startInner() - Method in class com.linkedin.venice.service.AbstractVeniceService
 
startInstanceMonitor(String) - Method in interface com.linkedin.venice.controller.Admin
 
startInstanceMonitor(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
startLeakedPushStatusCleanUpService() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
Cause LeakedPushStatusCleanUpService service to begin executing.
startMonitorOfflinePush(String, int, int, OfflinePushStrategy) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
startMonitorOfflinePush(String, int, int, OfflinePushStrategy) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
 
startMonitorOfflinePush(String, int, int, OfflinePushStrategy) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
startOfBufferReplay - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
If a StartOfBufferReplay has been consumed, then it is stored in its entirety here, otherwise, this field is null.
StartOfBufferReplay - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent by the Controller, once per partition, after the EndOfPush ControlMessage, in Hybrid Stores that ingest from both offline and nearline sources.
StartOfBufferReplay() - Constructor for class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
Default constructor.
StartOfBufferReplay(List<Long>, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
All-args constructor.
startOfBufferReplayDestinationOffset - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
This is the offset at which the StartOfBufferReplay control message was consumed in the current partition of the destination topic.
StartOfIncrementalPush - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent per partition by each offline incremental push job, once per partition, at the beginning of a incremental push.
StartOfIncrementalPush() - Constructor for class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
Default constructor.
StartOfIncrementalPush(CharSequence) - Constructor for class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
All-args constructor.
startOfIncrementalPushReceived(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
Consumption is started for an incremental push
startOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
startOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
startOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
startOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
startOfIncrementalPushReceived(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
StartOfPush - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent once per partition, at the beginning of a bulk load, before any of the data producers come online.
StartOfPush() - Constructor for class com.linkedin.venice.kafka.protocol.StartOfPush
Default constructor.
StartOfPush(Boolean, Boolean, Integer, ByteBuffer, Integer) - Constructor for class com.linkedin.venice.kafka.protocol.StartOfPush
All-args constructor.
startOfPushTimestamp - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
The messageTimestamp from the producerMetadata of StartOfPush control message.
StartOfSegment - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent at least once per partition per producer.
StartOfSegment() - Constructor for class com.linkedin.venice.kafka.protocol.StartOfSegment
Default constructor.
StartOfSegment(Integer, List<CharSequence>) - Constructor for class com.linkedin.venice.kafka.protocol.StartOfSegment
All-args constructor.
startPeriodicPing() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
startsWith(byte[]) - Method in class com.linkedin.venice.utils.ByteArray
 
startsWith(CharSequence) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string to determine if the specified string is a prefix.
startsWith(CharSequence, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string, starting at the specified offset, to determine if the specified string is a prefix.
startsWith(CharSequence, CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string to determine if the specified string is a prefix.
startsWith(CharSequence, CharSequence, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string, starting at the specified offset, to determine if the specified string is a prefix.
startsWithIgnoreCase(CharSequence, CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Compares the specified string to this string to determine if the specified string is a prefix.
startsWithIgnoreCase(CharSequence, CharSequence, int) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
startTimerTasks() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
startTrackingExecution(AdminCommandExecution) - Method in class com.linkedin.venice.controller.AdminCommandExecutionTracker
Add execution context into local memory and expired old executions if needed.
startup(String[]) - Method in class com.linkedin.alpini.cli.CLIArgumentParser
Parse the given command line.
startWaiters() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
 
state() - Method in class com.linkedin.alpini.netty4.handlers.VIPRequestHandler
 
StateModelIngestionProgressNotifier - Class in com.linkedin.davinci.helix
This class notifies the Helix State Models (SM) about corresponding ingestion progress.
StateModelIngestionProgressNotifier() - Constructor for class com.linkedin.davinci.helix.StateModelIngestionProgressNotifier
 
states - Variable in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
stateTransitionStats - Variable in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
StaticAccessController - Interface in com.linkedin.venice.acl
A StaticAccessController is an AccessController with an immutable resource list.
StaticClusterInfoProvider - Class in com.linkedin.venice.meta
 
StaticClusterInfoProvider(Set<String>) - Constructor for class com.linkedin.venice.meta.StaticClusterInfoProvider
 
StaticConfig(String, String, int) - Constructor for class com.linkedin.alpini.base.queuing.QOSPolicy.StaticConfig
 
Stats() - Constructor for class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
 
StatsAvroGenericDaVinciClient<K,​V> - Class in com.linkedin.davinci.client
Currently, we only expose metrics for single-get and batch-get requests, and if there is a need to have metrics for other request types, we can add them later.
StatsAvroGenericDaVinciClient(AvroGenericDaVinciClient<K, V>, ClientConfig) - Constructor for class com.linkedin.davinci.client.StatsAvroGenericDaVinciClient
 
StatsAvroGenericStoreClient<K,​V> - Class in com.linkedin.venice.fastclient
This class is in charge of all the metric emissions per request.
StatsAvroGenericStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.StatsAvroGenericStoreClient
 
StatsAvroSpecificDaVinciClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.davinci.client
 
StatsAvroSpecificDaVinciClient(AvroSpecificDaVinciClient<K, V>, ClientConfig) - Constructor for class com.linkedin.davinci.client.StatsAvroSpecificDaVinciClient
 
StatsAvroSpecificStoreClient<K,​V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient
 
StatsAvroSpecificStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.StatsAvroSpecificStoreClient
 
StatsErrorCode - Enum in com.linkedin.venice.stats
This enum tracks the error codes that we use to report anomalies in metrics.
StatsHandler - Class in com.linkedin.venice.listener
 
StatsHandler(AggServerHttpRequestStats, AggServerHttpRequestStats, AggServerHttpRequestStats) - Constructor for class com.linkedin.venice.listener.StatsHandler
 
StatsSupplier<T extends AbstractVeniceStats> - Interface in com.linkedin.venice.stats
 
StatsUtils - Class in com.linkedin.venice.stats
 
StatsUtils() - Constructor for class com.linkedin.venice.stats.StatsUtils
 
StatTrackingStoreClient<K,​V> - Class in com.linkedin.venice.client.store
This class is used to handle all the metric related logic.
StatTrackingStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.client.store.StatTrackingStoreClient
 
status - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
status - Variable in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Final HTTP status code (non-200) after processing the streaming request completely
status - Variable in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
status - Variable in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
replica status
status - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Status of version, and default is 'STARTED'
status() - Method in exception com.linkedin.alpini.base.misc.ExceptionWithStatus
 
status() - Method in exception com.linkedin.alpini.netty4.misc.ExceptionWithResponseStatus
 
status() - Method in interface com.linkedin.alpini.netty4.misc.HttpMultiPart
 
status() - Method in exception com.linkedin.alpini.router.api.Netty4RouterException
 
status(Class<STATUS>) - Method in exception com.linkedin.alpini.base.misc.ExceptionWithStatus
 
STATUS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
StatusMessage - Class in com.linkedin.venice.status
Venice control message which is used to transfer command and status between storage node and controller, so that controller could control the whole cluster and make the global decision.
StatusMessage() - Constructor for class com.linkedin.venice.status.StatusMessage
Default constructor, only used in constructor of sub-class.
StatusMessage(Map<String, String>) - Constructor for class com.linkedin.venice.status.StatusMessage
Create message from given fields map.
StatusMessageChannel - Interface in com.linkedin.venice.status
Channel used to send and receive control message.
StatusMessageHandler<T extends StatusMessage> - Interface in com.linkedin.venice.status
Handler to deal with incoming StatusMessage instances.
statusOf(int) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
statusOf(int) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
statusReportAdapter - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
StatusReportAdapter - Class in com.linkedin.davinci.kafka.consumer
This class forwards status report requests to IngestionNotificationDispatcher at USER partition level.
StatusReportAdapter(IngestionNotificationDispatcher, AmplificationFactorAdapter) - Constructor for class com.linkedin.davinci.kafka.consumer.StatusReportAdapter
 
StatusSnapshot - Class in com.linkedin.venice.pushmonitor
The snapshot of status change.
StatusSnapshot(ExecutionStatus, String) - Constructor for class com.linkedin.venice.pushmonitor.StatusSnapshot
 
StatusSnapshotSerializerMixin(ExecutionStatus, String) - Constructor for class com.linkedin.venice.helix.OfflinePushStatusJSONSerializer.StatusSnapshotSerializerMixin
 
StickyEventExecutorChooserFactory - Class in com.linkedin.alpini.netty4.misc
Created by acurtis on 12/12/16.
StickyEventExecutorChooserFactory() - Constructor for class com.linkedin.alpini.netty4.misc.StickyEventExecutorChooserFactory
 
stop() - Method in interface com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumer
 
stop() - Method in class com.linkedin.venice.controller.VeniceController
Causes venice controller and its associated services to stop executing.
stop() - Method in class com.linkedin.venice.grpc.VeniceGrpcServer
 
stop() - Method in class com.linkedin.venice.hadoop.heartbeat.NoOpPushJobHeartbeatSender
 
stop() - Method in interface com.linkedin.venice.hadoop.heartbeat.PushJobHeartbeatSender
 
stop() - Method in class com.linkedin.venice.router.api.VeniceDispatcher
 
stop() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
 
stop() - Method in class com.linkedin.venice.service.AbstractVeniceService
 
stop(String) - Method in interface com.linkedin.venice.controller.Admin
Stop the helix controller for a single cluster.
stop(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
stop(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
STOP_CONSUMPTION - com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
 
stopAllMonitoring() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
stopAllMonitoring() - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Stop monitoring all offline pushes.
stopAllMonitoring() - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
stopAllStateModelThreads() - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
 
stopConsumption(boolean) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
stopConsumption(VeniceStoreVersionConfig, int) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
 
stopConsumption(VeniceStoreVersionConfig, int) - Method in interface com.linkedin.davinci.ingestion.IngestionBackendBase
 
stopConsumption(VeniceStoreVersionConfig, int) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
 
stopConsumption(VeniceStoreVersionConfig, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
Stops consuming messages from Kafka Partition corresponding to Venice Partition.
stopConsumption(VeniceStoreVersionConfig, int) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Stops consuming messages from Kafka Partition corresponding to Venice Partition.
stopConsumption(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
stopConsumptionAndWait(VeniceStoreVersionConfig, int, int, int, boolean) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
Stops consuming messages from Kafka Partition corresponding to Venice Partition and wait up to (sleepSeconds * numRetires) to make sure partition consumption is stopped.
stopConsumptionAndWait(VeniceStoreVersionConfig, int, int, int, boolean) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
Stops consuming messages from Kafka Partition corresponding to Venice Partition and wait up to (sleepSeconds * numRetires) to make sure partition consumption is stopped.
stopErrorPartitionResetTask() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
Cause ErrorPartitionResetTask service to stop executing.
stopInner() - Method in class com.linkedin.davinci.helix.HelixParticipationService
 
stopInner() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
stopInner() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
 
stopInner() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
 
stopInner() - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
stopInner() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
stopInner() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
stopInner() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
Stops all the Kafka consumption tasks.
stopInner() - Method in class com.linkedin.davinci.kafka.consumer.RemoteIngestionRepairService
 
stopInner() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
stopInner() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
stopInner() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
 
stopInner() - Method in class com.linkedin.davinci.storage.DiskHealthCheckService
 
stopInner() - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
 
stopInner() - Method in class com.linkedin.davinci.storage.StorageService
 
stopInner() - Method in class com.linkedin.venice.cleaner.BackupVersionOptimizationService
 
stopInner() - Method in class com.linkedin.venice.cleaner.LeakedResourceCleaner
 
stopInner() - Method in class com.linkedin.venice.controller.DisabledPartitionEnablerService
 
stopInner() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
 
stopInner() - Method in class com.linkedin.venice.controller.kafka.TopicCleanupService
 
stopInner() - Method in class com.linkedin.venice.controller.server.AdminSparkServer
 
stopInner() - Method in class com.linkedin.venice.controller.StoreBackupVersionCleanupService
 
stopInner() - Method in class com.linkedin.venice.controller.StoreGraveyardCleanupService
 
stopInner() - Method in class com.linkedin.venice.controller.systemstore.SystemStoreRepairService
 
stopInner() - Method in class com.linkedin.venice.controller.UnusedValueSchemaCleanupService
 
stopInner() - Method in class com.linkedin.venice.controller.VeniceControllerService
Causes VeniceControllerService to stop executing.
stopInner() - Method in class com.linkedin.venice.listener.ListenerService
 
stopInner() - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
stopInner() - Method in class com.linkedin.venice.pushmonitor.LeakedPushStatusCleanUpService
 
stopInner() - Method in class com.linkedin.venice.router.api.DictionaryRetrievalService
 
stopInner() - Method in class com.linkedin.venice.router.api.RouterHeartbeat
 
stopInner() - Method in class com.linkedin.venice.router.RouterServer
 
stopInner() - Method in class com.linkedin.venice.service.AbstractVeniceService
 
stopLeakedPushStatusCleanUpService() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
Cause LeakedPushStatusCleanUpService service to stop executing.
stopMonitorOfflinePush(String, boolean, boolean) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
 
stopMonitorOfflinePush(String, boolean, boolean) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
Stop monitoring a push.
stopMonitorOfflinePush(String, boolean, boolean) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
 
stopMonitorOfflinePush(String, String, boolean, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
stopped(String, int, long) - Method in class com.linkedin.davinci.helix.StateModelIngestionProgressNotifier
 
stopped(String, int, long) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
stopped(String, int, long) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
stopped(String, int, long) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
stopped(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
STOPPED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
STOPPED - com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
 
STOPPED - com.linkedin.venice.service.AbstractVeniceService.ServiceState
 
stopPeriodicPing() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
stopTimerTasks() - Method in class com.linkedin.venice.helix.SafeHelixManager
 
stopVeniceController() - Method in interface com.linkedin.venice.controller.Admin
Stop the entire controller but not only the helix controller for a single cluster.
stopVeniceController() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
stopVeniceController() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
STORAGE - com.linkedin.venice.meta.QueryAction
 
STORAGE_ENGINE_OVERHEAD_RATIO - com.linkedin.venice.controllerapi.ControllerRoute
 
STORAGE_ENGINE_OVERHEAD_RATIO - Static variable in class com.linkedin.venice.ConfigKeys
This factor is used to estimate potential push size.
STORAGE_ENGINE_OVERHEAD_RATIO - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
STORAGE_NODE - com.linkedin.venice.Arg
 
STORAGE_NODE_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORAGE_NODE_READ_QUOTA_ENABLED - com.linkedin.venice.Arg
 
STORAGE_NODE_READ_QUOTA_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORAGE_PERSONA - com.linkedin.venice.Arg
 
STORAGE_PERSONA_SUB_PATH - Static variable in class com.linkedin.venice.persona.StoragePersonaAccessor
 
STORAGE_QUOTA - com.linkedin.venice.Arg
 
STORAGE_QUOTA_IN_BYTE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORAGE_QUOTA_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
STORAGE_SERVICE - com.linkedin.venice.ingestion.protocol.enums.IngestionComponentType
 
StorageClass - Enum in com.linkedin.davinci.client
 
storageConsumeRcu(int) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
 
storageEngine - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
StorageEngineBackedCompressorFactory - Class in com.linkedin.davinci.compression
 
StorageEngineBackedCompressorFactory(StorageMetadataService) - Constructor for class com.linkedin.davinci.compression.StorageEngineBackedCompressorFactory
 
StorageEngineFactory - Class in com.linkedin.davinci.store
An abstraction that represents the shared resources of a persistence engine.
StorageEngineFactory() - Constructor for class com.linkedin.davinci.store.StorageEngineFactory
 
StorageEngineInitializationException - Exception in com.linkedin.davinci.store
This exception indicates that the server was unable to initialize on or more storage services or stores within a service.
StorageEngineInitializationException() - Constructor for exception com.linkedin.davinci.store.StorageEngineInitializationException
 
StorageEngineInitializationException(String) - Constructor for exception com.linkedin.davinci.store.StorageEngineInitializationException
 
StorageEngineInitializationException(String, Throwable) - Constructor for exception com.linkedin.davinci.store.StorageEngineInitializationException
 
StorageEngineInitializationException(Throwable) - Constructor for exception com.linkedin.davinci.store.StorageEngineInitializationException
 
StorageEngineMetadataService - Class in com.linkedin.davinci.storage
StorageEngineMetadataService is wrapper service on top of storageEngineRepository to serve read/write to storage metadata.
StorageEngineMetadataService(StorageEngineRepository, InternalAvroSpecificSerializer<PartitionState>) - Constructor for class com.linkedin.davinci.storage.StorageEngineMetadataService
 
StorageEngineOverheadRatioResponse - Class in com.linkedin.venice.controllerapi
 
StorageEngineOverheadRatioResponse() - Constructor for class com.linkedin.venice.controllerapi.StorageEngineOverheadRatioResponse
 
storageEngineRepository - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
storage destination for consumption
StorageEngineRepository - Class in com.linkedin.davinci.storage
A wrapper class that holds all the server's storage engines.
StorageEngineRepository() - Constructor for class com.linkedin.davinci.storage.StorageEngineRepository
 
StorageInitializationException - Exception in com.linkedin.venice.exceptions
thrown by StorageEngineFactory and AbstractStorageEngine when storage creation fails
StorageInitializationException() - Constructor for exception com.linkedin.venice.exceptions.StorageInitializationException
 
StorageInitializationException(String) - Constructor for exception com.linkedin.venice.exceptions.StorageInitializationException
 
StorageInitializationException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.StorageInitializationException
 
StorageInitializationException(Throwable) - Constructor for exception com.linkedin.venice.exceptions.StorageInitializationException
 
storageMetadataService - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
StorageMetadataService - Interface in com.linkedin.davinci.storage
This is a superset of the OffsetManager APIs, which also provide functions for storing store-version level state.
StorageNodeClient - Interface in com.linkedin.venice.router.httpclient
 
StorageNodeClientType - Enum in com.linkedin.venice.router.httpclient
 
storageNodeReadQuotaEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether storage node read quota is enabled for this store
storageNodeReadQuotaEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Controls the storage node read quota enforcement for the given Venice store
StorageNodeStatus - Class in com.linkedin.venice.controller
Class used to represent the status of storage node.
StorageNodeStatus() - Constructor for class com.linkedin.venice.controller.StorageNodeStatus
 
StoragePartitionConfig - Class in com.linkedin.davinci.store
Storage partition level config, which could be used to specify partition specific config when initializing/opening the corresponding AbstractStoragePartition.
StoragePartitionConfig(String, int) - Constructor for class com.linkedin.davinci.store.StoragePartitionConfig
 
StoragePartitionDiskUsage - Class in com.linkedin.davinci.utils
This class maintains in-memory partition usage.
StoragePartitionDiskUsage(int, AbstractStorageEngine) - Constructor for class com.linkedin.davinci.utils.StoragePartitionDiskUsage
 
StoragePartitionInitializationException - Exception in com.linkedin.davinci.store
This exception indicates that the server was unable to initialize on or more storage services or stores within a service.
StoragePartitionInitializationException() - Constructor for exception com.linkedin.davinci.store.StoragePartitionInitializationException
 
StoragePartitionInitializationException(String) - Constructor for exception com.linkedin.davinci.store.StoragePartitionInitializationException
 
StoragePartitionInitializationException(String, Throwable) - Constructor for exception com.linkedin.davinci.store.StoragePartitionInitializationException
 
StoragePartitionInitializationException(Throwable) - Constructor for exception com.linkedin.davinci.store.StoragePartitionInitializationException
 
storagePersona - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
The name of the StoragePersona to add to the store
StoragePersona - Class in com.linkedin.venice.persona
A type of Persona that enforces a storage (size) limit across multiple stores.
StoragePersona() - Constructor for class com.linkedin.venice.persona.StoragePersona
 
StoragePersona(StoragePersona) - Constructor for class com.linkedin.venice.persona.StoragePersona
 
StoragePersona(String, long, Set<String>, Set<String>) - Constructor for class com.linkedin.venice.persona.StoragePersona
 
StoragePersonaAccessor - Class in com.linkedin.venice.persona
Zookeeper accessor for StoragePersona objects, allowing for read/write to persona paths.
StoragePersonaAccessor(String, HelixAdapterSerializer, ZkClient) - Constructor for class com.linkedin.venice.persona.StoragePersonaAccessor
 
StoragePersonaJSONSerializer - Class in com.linkedin.venice.persona
Serializer used to convert the data between Persona and json.
StoragePersonaJSONSerializer() - Constructor for class com.linkedin.venice.persona.StoragePersonaJSONSerializer
 
StoragePersonaJSONSerializer.StoragePersonaSerializerMixin - Class in com.linkedin.venice.persona
This class annotates the constructor for StoragePersona and serves as a property-based creator.
StoragePersonaRepository - Class in com.linkedin.venice.helix
Cached wrapper for the StoragePersonaAccessor class, which keeps a map of store names to personas that contain them, as well as caches Zookeeper personas.
StoragePersonaRepository(String, ReadOnlyStoreRepository, HelixAdapterSerializer, ZkClient) - Constructor for class com.linkedin.venice.helix.StoragePersonaRepository
 
StoragePersonaRepository.StoragePersonaStoreDataListener - Class in com.linkedin.venice.helix
Helper class which listens to changes from a ReadOnlyStoreRepository and updates the caches and ZK of the StoragePersonaRepository accordingly.
StoragePersonaResponse - Class in com.linkedin.venice.controllerapi
 
StoragePersonaResponse() - Constructor for class com.linkedin.venice.controllerapi.StoragePersonaResponse
 
StoragePersonaRoutes - Class in com.linkedin.venice.controller.server
 
StoragePersonaRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.StoragePersonaRoutes
 
StoragePersonaSerializerMixin(String, long, Set<String>, Set<String>) - Constructor for class com.linkedin.venice.persona.StoragePersonaJSONSerializer.StoragePersonaSerializerMixin
 
StoragePersonaStoreDataListener(StoragePersonaRepository) - Constructor for class com.linkedin.venice.helix.StoragePersonaRepository.StoragePersonaStoreDataListener
 
storageQuotaInByte - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
storageQuotaInByte - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
storageQuotaInByte - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Maximum capacity a store version is able to have, and default is 20GB
StorageReadRequestHandler - Class in com.linkedin.venice.listener
StorageReadRequestHandler will take the incoming read requests from routerRouterRequest, and delegate the lookup request to a thread pool StorageReadRequestHandler.executor, which is being shared by all the requests.
StorageReadRequestHandler(ThreadPoolExecutor, ThreadPoolExecutor, StorageEngineRepository, ReadOnlyStoreRepository, ReadOnlySchemaRepository, IngestionMetadataRetriever, ReadMetadataRetriever, DiskHealthCheckService, boolean, boolean, int, VeniceServerConfig, StorageEngineBackedCompressorFactory, Optional<ResourceReadUsageTracker>) - Constructor for class com.linkedin.venice.listener.StorageReadRequestHandler
 
StorageResponseObject - Class in com.linkedin.venice.listener.response
 
StorageResponseObject() - Constructor for class com.linkedin.venice.listener.response.StorageResponseObject
 
StorageService - Class in com.linkedin.davinci.storage
Storage interface to Venice Server, Da Vinci and Isolated Ingestion Service.
StorageService(VeniceConfigLoader, AggVersionedStorageEngineStats, RocksDBMemoryStats, InternalAvroSpecificSerializer<StoreVersionState>, InternalAvroSpecificSerializer<PartitionState>, ReadOnlyStoreRepository) - Constructor for class com.linkedin.davinci.storage.StorageService
 
StorageService(VeniceConfigLoader, AggVersionedStorageEngineStats, RocksDBMemoryStats, InternalAvroSpecificSerializer<StoreVersionState>, InternalAvroSpecificSerializer<PartitionState>, ReadOnlyStoreRepository, boolean, boolean) - Constructor for class com.linkedin.davinci.storage.StorageService
 
StorageService(VeniceConfigLoader, AggVersionedStorageEngineStats, RocksDBMemoryStats, InternalAvroSpecificSerializer<StoreVersionState>, InternalAvroSpecificSerializer<PartitionState>, ReadOnlyStoreRepository, boolean, boolean, Function<String, Boolean>) - Constructor for class com.linkedin.davinci.storage.StorageService
 
StorageUtilizationManager - Class in com.linkedin.davinci.kafka.consumer
This class has the following responsibilities: 1.
StorageUtilizationManager(AbstractStorageEngine, Store, String, int, Map<Integer, PartitionConsumptionState>, boolean, boolean, StatusReportAdapter, TopicPartitionConsumerFunction, TopicPartitionConsumerFunction) - Constructor for class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
 
store - Variable in class com.linkedin.venice.datarecovery.Command.Params
 
store - Variable in class com.linkedin.venice.views.VeniceView
 
store() - Method in class com.linkedin.davinci.config.StoreBackendConfig
 
Store - Interface in com.linkedin.venice.meta
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
STORE - com.linkedin.venice.Arg
 
STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
STORE - com.linkedin.venice.controllerapi.routes.V1Delete
 
STORE - com.linkedin.venice.controllerapi.routes.V1Get
 
STORE - com.linkedin.venice.controllerapi.routes.V1Post
 
STORE - com.linkedin.venice.controllerapi.routes.V1Put
 
STORE_ATTRIBUTES - com.linkedin.venice.common.StoreMetadataType
 
STORE_CLUSTER_CONFIG - com.linkedin.venice.system.store.MetaStoreDataType
 
STORE_CONFIG_NAME_FILTER - com.linkedin.venice.Arg
 
STORE_CONFIG_NAME_FILTER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
An optional argument in list-store command; pass in a store config to select stores.
STORE_CONFIG_VALUE_FILTER - com.linkedin.venice.Arg
 
STORE_CONFIG_VALUE_FILTER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
An optional argument in list-store command; if the config name argument is used in the command, users must specify the config value filter too.
STORE_CREATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
STORE_GRAVEYARD_PATH - Static variable in class com.linkedin.venice.helix.HelixStoreGraveyard
 
STORE_KEY_SCHEMAS - com.linkedin.venice.common.StoreMetadataType
 
STORE_KEY_SCHEMAS - com.linkedin.venice.system.store.MetaStoreDataType
 
STORE_MAX_LENGTH - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
STORE_METADATA_FETCH_MODES - Static variable in class com.linkedin.venice.fastclient.utils.ClientTestUtils
 
STORE_MIGRATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORE_MIGRATION_ALLOWED - com.linkedin.venice.controllerapi.ControllerRoute
 
STORE_NAME_FOR_TOTAL_STAT - Static variable in class com.linkedin.venice.stats.AbstractVeniceAggStats
 
STORE_NOT_FOUND - com.linkedin.venice.exceptions.ErrorType
 
STORE_NOT_FOUND - com.linkedin.venice.exceptions.ExceptionType
Deprecated.
 
STORE_PATTERN - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
STORE_PROPERTIES - com.linkedin.venice.system.store.MetaStoreDataType
 
STORE_REPLICA_STATUSES - com.linkedin.venice.system.store.MetaStoreDataType
 
STORE_REPOSITORY_PATH - Static variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
STORE_SIZE - com.linkedin.venice.Arg
 
STORE_SIZE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORE_TYPE - com.linkedin.venice.Arg
 
STORE_TYPE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORE_VALUE_SCHEMA - com.linkedin.venice.system.store.MetaStoreDataType
 
STORE_VALUE_SCHEMAS - com.linkedin.venice.common.StoreMetadataType
 
STORE_VALUE_SCHEMAS - com.linkedin.venice.system.store.MetaStoreDataType
 
STORE_VERSION_POLLING_DELAY_MS - Static variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
STORE_VERSION_SHOULD_NOT_EMIT_METRICS - com.linkedin.venice.stats.StatsErrorCode
The original metrics implementation dealt with the problem of proliferation of transient metrics in downstream reporting systems by only reporting on one of the store versions, and by avoiding the inclusion of the version number as part of the metric name.
STORE_VERSION_STATE - com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Used to persist state related to a store-version, including Start of Buffer Replay offsets and whether the input is sorted.
STORE_VERSION_STATE_UNAVAILABLE - com.linkedin.venice.stats.StatsErrorCode
Some metrics rely on the data contained in: StoreVersionState If this state is not available, the metric cannot be computed and this error code will be emitted.
STORE_VIEW - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORE_VIEW_CLASS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORE_VIEW_CONFIGS - com.linkedin.venice.Arg
 
STORE_VIEW_NAME - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORE_VIEW_PARAMS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
STORE_WRITER_BUFFER_AFTER_LEADER_LOGIC_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
 
STORE_WRITER_BUFFER_MEMORY_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
 
STORE_WRITER_BUFFER_NOTIFY_DELTA - Static variable in class com.linkedin.venice.ConfigKeys
 
STORE_WRITER_NUMBER - Static variable in class com.linkedin.venice.ConfigKeys
 
StoreAclHandler - Class in com.linkedin.venice.acl.handler
Store-level access control handler, which is being used by both Router and Server.
StoreAclHandler(DynamicAccessController, ReadOnlyStoreRepository) - Constructor for class com.linkedin.venice.acl.handler.StoreAclHandler
 
StoreAttributes - Class in com.linkedin.venice.meta.systemstore.schemas
This type of metadata contains various store properties/configs and describes the clusters that store is materialized in.
StoreAttributes() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
Default constructor.
StoreAttributes(StoreProperties, CharSequence, List<CharSequence>) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
All-args constructor.
StoreBackend - Class in com.linkedin.davinci
 
StoreBackendConfig - Class in com.linkedin.davinci.config
 
StoreBackendConfig(String, String) - Constructor for class com.linkedin.davinci.config.StoreBackendConfig
 
StoreBackendStats - Class in com.linkedin.davinci
 
StoreBackendStats(MetricsRepository, String) - Constructor for class com.linkedin.davinci.StoreBackendStats
 
StoreBackupVersionCleanupService - Class in com.linkedin.venice.controller
This service is in charge of cleaning up backup versions based on retention policy defined on store basis.
StoreBackupVersionCleanupService(VeniceHelixAdmin, VeniceControllerMultiClusterConfig, Time, MetricsRepository) - Constructor for class com.linkedin.venice.controller.StoreBackupVersionCleanupService
 
StoreBackupVersionCleanupService(VeniceHelixAdmin, VeniceControllerMultiClusterConfig, MetricsRepository) - Constructor for class com.linkedin.venice.controller.StoreBackupVersionCleanupService
 
StoreBackupVersionCleanupServiceStats - Class in com.linkedin.venice.controller.stats
 
StoreBackupVersionCleanupServiceStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.StoreBackupVersionCleanupServiceStats
 
storeBufferService - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
StoreBufferService - Class in com.linkedin.davinci.kafka.consumer
This class is serving as a PubSubMessage buffer with an accompanying pool of drainer threads.
StoreBufferService(int, long, long, boolean, StoreBufferServiceStats) - Constructor for class com.linkedin.davinci.kafka.consumer.StoreBufferService
Constructor for testing
StoreBufferService(int, long, long, boolean, MetricsRepository, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.StoreBufferService
 
StoreBufferServiceStats - Class in com.linkedin.davinci.stats
 
StoreBufferServiceStats(MetricsRepository, LongSupplier, LongSupplier, LongSupplier, LongSupplier) - Constructor for class com.linkedin.davinci.stats.StoreBufferServiceStats
 
StoreCacheStats - Class in com.linkedin.davinci.store.cache.backend
 
StoreCacheStats(MetricsRepository, String) - Constructor for class com.linkedin.davinci.store.cache.backend.StoreCacheStats
 
StoreChangeListener() - Constructor for class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository.StoreChangeListener
 
StoreCleaner - Interface in com.linkedin.venice.meta
 
storeClient - Variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
StoreClientTestUtils - Class in com.linkedin.venice.client.utils
 
StoreClientTestUtils() - Constructor for class com.linkedin.venice.client.utils.StoreClientTestUtils
 
storeClusterConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
This is the Zk's StoreConfig equivalent which contains various Venice cluster information
StoreClusterConfig - Class in com.linkedin.venice.systemstore.schemas
This type describes the various Venice cluster information for a store
StoreClusterConfig() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
Default constructor.
StoreClusterConfig(CharSequence, Boolean, CharSequence, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
All-args constructor.
StoreComparisonInfo - Class in com.linkedin.venice.controllerapi
 
StoreComparisonInfo() - Constructor for class com.linkedin.venice.controllerapi.StoreComparisonInfo
 
StoreComparisonResponse - Class in com.linkedin.venice.controllerapi
 
StoreComparisonResponse() - Constructor for class com.linkedin.venice.controllerapi.StoreComparisonResponse
 
storeCompressionStrategy - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
StoreConfig - Class in com.linkedin.venice.meta
Configurations of a store which are non-cluster specified.
StoreConfig(StoreClusterConfig) - Constructor for class com.linkedin.venice.meta.StoreConfig
 
StoreConfig(String) - Constructor for class com.linkedin.venice.meta.StoreConfig
 
StoreConfigAddedOrDeletedChangedListener() - Constructor for class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository.StoreConfigAddedOrDeletedChangedListener
 
StoreConfigChangedListener() - Constructor for class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository.StoreConfigChangedListener
 
StoreConfigJsonSerializer - Class in com.linkedin.venice.helix
 
StoreConfigJsonSerializer() - Constructor for class com.linkedin.venice.helix.StoreConfigJsonSerializer
 
StoreConfigJsonSerializer.StoreConfigSerializerMixin - Class in com.linkedin.venice.helix
 
StoreConfigSerializerMixin(String) - Constructor for class com.linkedin.venice.helix.StoreConfigJsonSerializer.StoreConfigSerializerMixin
 
StoreCreation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
StoreCreation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
Default constructor.
StoreCreation(CharSequence, CharSequence, CharSequence, SchemaMeta, SchemaMeta) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
All-args constructor.
StoreDataAudit - Class in com.linkedin.venice.meta
This is a class used to manage multiple replicas of the same store.
StoreDataAudit() - Constructor for class com.linkedin.venice.meta.StoreDataAudit
 
StoreDataChangedListener - Interface in com.linkedin.venice.meta
Interface used to register into metadata repository to listen the change of store data.
storeDeserializerCache - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
storeDeserializerCache - Variable in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
storeDeserializerCache - Variable in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
 
StoreDeserializerCache<T> - Interface in com.linkedin.venice.serialization
 
StoreDisabledException - Exception in com.linkedin.venice.exceptions
 
StoreDisabledException(String, String) - Constructor for exception com.linkedin.venice.exceptions.StoreDisabledException
 
StoreDisabledException(String, String, int) - Constructor for exception com.linkedin.venice.exceptions.StoreDisabledException
 
StoreETLConfig - Class in com.linkedin.venice.systemstore.schemas
 
StoreETLConfig() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreETLConfig
Default constructor.
StoreETLConfig(CharSequence, Boolean, Boolean) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreETLConfig
All-args constructor.
storeFlattened(File) - Method in class com.linkedin.venice.utils.VeniceProperties
Store all properties in a file
storeFlattened(OutputStream) - Method in class com.linkedin.venice.utils.VeniceProperties
Store all properties to an OutputStream
StoreGraveyard - Interface in com.linkedin.venice.meta
The graveyard used to keep all deleted stores.
StoreGraveyardCleanupService - Class in com.linkedin.venice.controller
This service is in charge of removing stores under /venice//StoreGraveyard zk path.
StoreGraveyardCleanupService(VeniceParentHelixAdmin, VeniceControllerMultiClusterConfig) - Constructor for class com.linkedin.venice.controller.StoreGraveyardCleanupService
 
StoreHealthAuditResponse - Class in com.linkedin.venice.controllerapi
 
StoreHealthAuditResponse() - Constructor for class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
 
StoreHybridConfig - Class in com.linkedin.venice.systemstore.schemas
 
StoreHybridConfig() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
Default constructor.
StoreHybridConfig(Long, Long, Long, Integer, Integer) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
All-args constructor.
StoreInfo - Class in com.linkedin.venice.meta
Json-serializable class for sending store information to the controller client
StoreInfo() - Constructor for class com.linkedin.venice.meta.StoreInfo
 
StoreIngestionService - Interface in com.linkedin.davinci.kafka.consumer
An interface for Store Ingestion Service for Venice.
StoreIngestionTask - Class in com.linkedin.davinci.kafka.consumer
A runnable Kafka Consumer consuming messages from all the partition assigned to current node for a Kafka Topic.
StoreIngestionTask(StoreIngestionTaskFactory.Builder, Store, Version, Properties, BooleanSupplier, VeniceStoreVersionConfig, int, boolean, Optional<ObjectCacheBackend>, Function<Integer, DaVinciRecordTransformer>, Queue<VeniceNotifier>) - Constructor for class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
StoreIngestionTask.DelegateConsumerRecordResult - Enum in com.linkedin.davinci.kafka.consumer
This enum represents all potential results after calling StoreIngestionTask.delegateConsumerRecord(PubSubMessage, int, String, int, long, long).
StoreIngestionTaskFactory - Class in com.linkedin.davinci.kafka.consumer
 
StoreIngestionTaskFactory.Builder - Class in com.linkedin.davinci.kafka.consumer
Builder class for StoreIngestionTaskFactory; once the build() function is invoked, no modification is allowed on any parameters.
StoreJSONSerializer - Class in com.linkedin.venice.helix
Serializer used to convert the data between Store and json.
StoreJSONSerializer() - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer
 
StoreJSONSerializer.ETLStoreConfigSerializerMixin - Class in com.linkedin.venice.helix
 
StoreJSONSerializer.HybridStoreConfigSerializerMixin - Class in com.linkedin.venice.helix
Mixin used to add the annotation to figure out the constructor used by Jackson lib when deserialize the version
StoreJSONSerializer.PartitionerConfigSerializerMixin - Class in com.linkedin.venice.helix
 
StoreJSONSerializer.StoreSerializerMixin - Class in com.linkedin.venice.helix
Mixin used to add the annotation to figure out the constructor used by Jackson lib when deserialize the store.
StoreJSONSerializer.VersionSerializerMixin - Class in com.linkedin.venice.helix
Mixin used to add the annotation to figure out the constructor used by Jackson lib when deserialize the version
StoreJSONSerializer.ViewConfigSerializerMixin - Class in com.linkedin.venice.helix
 
storeKafkaClusterMap(File, String, Map<String, Map<String, String>>) - Static method in class com.linkedin.davinci.config.VeniceConfigLoader
 
storeKafkaClusterMap(File, Map<String, Map<String, String>>) - Static method in class com.linkedin.davinci.config.VeniceConfigLoader
 
storeKeySchema - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
StoreKeySchemaExistException - Exception in com.linkedin.venice.exceptions
Throw this exception when try to add key schema to a store, whose key schema already exists.
storeKeySchemas - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
StoreKeySchemas - Class in com.linkedin.venice.meta.systemstore.schemas
This type of store metadata describes the key schemas of the store
StoreKeySchemas - Class in com.linkedin.venice.systemstore.schemas
This type describes the key schemas of the store
StoreKeySchemas() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
Default constructor.
StoreKeySchemas() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
Default constructor.
StoreKeySchemas(Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
All-args constructor.
StoreKeySchemas(Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
All-args constructor.
StoreLifecycleEventOutcome - Enum in com.linkedin.venice.hooks
 
StoreLifecycleHooks - Class in com.linkedin.venice.hooks
This interface defines a set of lifecycle events for stores and their store-versions.

Pre-hooks and post-hooks

Most events have a pre- and post- variant, all pre-hooks provide an option to control the outcome of the event (e.g.
StoreLifecycleHooks(VeniceProperties) - Constructor for class com.linkedin.venice.hooks.StoreLifecycleHooks
 
StoreListChangedListener - Interface in com.linkedin.venice.meta
Interface used to register into metadata repository to listen the change of store list.
storeMap - Variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
StoreMetadata - Interface in com.linkedin.venice.fastclient.meta
This interface defines the APIs to retrieve store metadata and routing data, and it also includes the feedback APIs: StoreMetadata.trackHealthBasedOnRequestToInstance(java.lang.String, int, int, java.util.concurrent.CompletableFuture<com.linkedin.venice.client.store.transport.TransportClientResponse>) to decide the healthiness of each replica.
StoreMetadataFetchMode - Enum in com.linkedin.venice.fastclient.meta
Modes that control how fast client will fetch store metadata
StoreMetadataKey - Class in com.linkedin.venice.meta.systemstore.schemas
A composite key that divides the key space to retrieve different types of metadata for a Venice store.
StoreMetadataKey() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
Default constructor.
StoreMetadataKey(List<CharSequence>, Integer) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
All-args constructor.
storeMetadataRepo - Variable in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
storeMetadataSystemStoreEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not the store metadata system store is enabled for this store.
StoreMetadataType - Enum in com.linkedin.venice.common
 
storeMetadataUpdate(String, String, VeniceHelixAdmin.StoreMetadataOperation) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update the store metadata by applying provided operation.
StoreMetadataValue - Class in com.linkedin.venice.meta.systemstore.schemas
 
StoreMetadataValue() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
Default constructor.
StoreMetadataValue(Long, Object) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
All-args constructor.
StoreMetaKey - Class in com.linkedin.venice.systemstore.schemas
A composite key that divides the key space to retrieve different types of metadata for a Venice store.
StoreMetaKey() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreMetaKey
Default constructor.
StoreMetaKey(List<CharSequence>, Integer) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreMetaKey
All-args constructor.
storeMetaSystemStoreEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not the store meta system store is enabled for this store.
StoreMetaValue - Class in com.linkedin.venice.systemstore.schemas
 
StoreMetaValue() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Default constructor.
StoreMetaValue(Long, StoreProperties, StoreKeySchemas, StoreValueSchemas, StoreValueSchema, Map<CharSequence, StoreReplicaStatus>, List<Integer>, StoreClusterConfig) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreMetaValue
All-args constructor.
StoreMigrationResponse - Class in com.linkedin.venice.controllerapi
 
StoreMigrationResponse() - Constructor for class com.linkedin.venice.controllerapi.StoreMigrationResponse
 
storeName - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
storeName - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
storeName - Variable in class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
 
storeName - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
storeName - Variable in class com.linkedin.davinci.utils.ChunkAssembler
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
storeName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
storeName - Variable in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
storeName - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
storeName - Variable in class com.linkedin.venice.router.api.path.VenicePath
 
storeName - Variable in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
Name of the store which the running push job instance is pushing data to
storeName - Variable in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
storeName - Variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
The name of the store
storeName - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Name of the store which this version belong to.
storeNamePattern - Static variable in interface com.linkedin.venice.meta.Store
Store name rules: 1.
StorePartitionDataReceiver - Class in com.linkedin.davinci.kafka.consumer
 
StorePartitionDataReceiver(StoreIngestionTask, PubSubTopicPartition, String, int) - Constructor for class com.linkedin.davinci.kafka.consumer.StorePartitionDataReceiver
 
StorePartitionerConfig - Class in com.linkedin.venice.systemstore.schemas
 
StorePartitionerConfig() - Constructor for class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
Default constructor.
StorePartitionerConfig(CharSequence, Map<CharSequence, CharSequence>, Integer) - Constructor for class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
All-args constructor.
storeProperties - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
StoreProperties - Class in com.linkedin.venice.meta.systemstore.schemas
 
StoreProperties - Class in com.linkedin.venice.systemstore.schemas
This type contains all the store configs and the corresponding versions
StoreProperties() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
Default constructor.
StoreProperties() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreProperties
Default constructor.
StoreProperties(Boolean, CharSequence, Integer, Boolean, Integer, Boolean, Boolean, CharSequence, Long, Integer, Boolean, Boolean, ETLStoreConfig, Boolean, HybridStoreConfig, Boolean, Boolean, Boolean, Integer, Integer, Boolean, Boolean, CharSequence, Integer, CharSequence, CharSequence, Integer, PartitionerConfig, CharSequence, Boolean, Long, CharSequence, CharSequence, Boolean, Boolean, Long, Boolean, Boolean, Boolean, CharSequence, Boolean, Boolean) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
All-args constructor.
StoreProperties(CharSequence, CharSequence, Long, Integer, Integer, Long, Boolean, Boolean, Long, Integer, Integer, Integer, Integer, Integer, Long, StoreHybridConfig, Map<CharSequence, StoreViewConfig>, Boolean, Integer, Boolean, Boolean, Boolean, Integer, Integer, Boolean, Boolean, Boolean, Boolean, Integer, Boolean, Boolean, Integer, CharSequence, Integer, Boolean, Integer, Boolean, Boolean, StoreETLConfig, StorePartitionerConfig, Integer, Long, Long, Integer, Boolean, CharSequence, Boolean, Boolean, Boolean, Boolean, Long, Long, Boolean, List<StoreVersion>, Map<CharSequence, SystemStoreProperties>, Boolean, Boolean) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreProperties
All-args constructor.
StoreReplicaStatus - Class in com.linkedin.venice.systemstore.schemas
This structure will contain all kinds of info related to one replica
StoreReplicaStatus() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
Default constructor.
StoreReplicaStatus(Integer) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
All-args constructor.
storeReplicaStatuses - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
This field describes the replica statuses per version per partition, and the mapping is 'host_port' -> 'replica status'
storeRepository - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
storeRepository - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
StoreRepushCommand - Class in com.linkedin.venice.datarecovery
StoreRepushCommand contains the details of executing/processing repush command.
StoreRepushCommand() - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand
 
StoreRepushCommand(StoreRepushCommand.Params) - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand
 
StoreRepushCommand.Params - Class in com.linkedin.venice.datarecovery
 
StoreRepushCommand.Params.Builder - Class in com.linkedin.venice.datarecovery
 
StoreRepushCommand.Result - Class in com.linkedin.venice.datarecovery
 
storeResponse - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
StoreResponse - Class in com.linkedin.venice.controllerapi
 
StoreResponse() - Constructor for class com.linkedin.venice.controllerapi.StoreResponse
 
STORES - com.linkedin.venice.Arg
 
STORES - com.linkedin.venice.controllerapi.routes.V1Get
 
STORES_FAILED_REGEX - Static variable in class com.linkedin.venice.utils.TestStoragePersonaUtils
 
StoreSchemaFetcher - Interface in com.linkedin.venice.client.schema
This class is the public interface for Venice store user to fetch store schemas.
StoreSerializerMixin(String, String, long, PersistenceType, RoutingStrategy, ReadStrategy, OfflinePushStrategy, int, long, long, HybridStoreConfig, PartitionerConfig, int) - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer.StoreSerializerMixin
 
StoresRoutes - Class in com.linkedin.venice.controller.server
 
StoresRoutes(boolean, Optional<DynamicAccessController>, PubSubTopicRepository) - Constructor for class com.linkedin.venice.controller.server.StoresRoutes
 
StoreStateReader - Class in com.linkedin.venice.store
This class retrieves the corresponding Store object from a router endpoint which contains the latest store state.
storeStats - Variable in class com.linkedin.venice.router.api.VeniceVersionFinder
 
storeStats - Variable in class com.linkedin.venice.stats.AbstractVeniceAggStats
 
StoreStats - Class in com.linkedin.venice.controller.stats
 
StoreStats(String, MetricsRepository, ReadOnlyStoreRepository) - Constructor for class com.linkedin.venice.controller.stats.StoreStats
 
StoreStatus - Enum in com.linkedin.venice.meta
 
StoreStatusDecider - Class in com.linkedin.venice.controller.kafka
 
StoreStatusDecider() - Constructor for class com.linkedin.venice.controller.kafka.StoreStatusDecider
 
StoreStatusMessage - Class in com.linkedin.venice.status
Control description used to notify controller that the status of Offline push in Storage node.
StoreStatusMessage(String, int, String, ExecutionStatus) - Constructor for class com.linkedin.venice.status.StoreStatusMessage
 
StoreStatusMessage(Map<String, String>) - Constructor for class com.linkedin.venice.status.StoreStatusMessage
Override the constructor of StatusMessage, build description from given fiedls.
storesToEnforce - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
storesToEnforce - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
storeStorageQuota - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
storeType - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
storeType - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
storeUserPartitionMapping - Variable in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
StoreUtils - Class in com.linkedin.venice.utils
 
StoreUtils() - Constructor for class com.linkedin.venice.utils.StoreUtils
 
storeValueSchema - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
StoreValueSchema - Class in com.linkedin.venice.systemstore.schemas
This type describes a single version of the value schema of the store.
StoreValueSchema() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreValueSchema
Default constructor.
StoreValueSchema(CharSequence) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreValueSchema
All-args constructor.
storeValueSchemaIdsWrittenPerStoreVersion - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
This field described the set of value schemas id written by a store version.
storeValueSchemas - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
StoreValueSchemas - Class in com.linkedin.venice.meta.systemstore.schemas
This type of store metadata describes the value schemas of the store.
StoreValueSchemas - Class in com.linkedin.venice.systemstore.schemas
This type describes the value schemas of the store.
StoreValueSchemas() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
Default constructor.
StoreValueSchemas() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
Default constructor.
StoreValueSchemas(Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
All-args constructor.
StoreValueSchemas(Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
All-args constructor.
StoreValueSchemasCacheService - Class in com.linkedin.venice.listener
This class implements the fast value schema/latest value schema lookup with acceptable delay.
StoreValueSchemasCacheService(ReadOnlyStoreRepository, ReadOnlySchemaRepository) - Constructor for class com.linkedin.venice.listener.StoreValueSchemasCacheService
 
storeVersion - Variable in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
Version of the store which the running push job instance is pushing data to
StoreVersion - Class in com.linkedin.venice.systemstore.schemas
Type describes all the version attributes
StoreVersion() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreVersion
Default constructor.
StoreVersion(CharSequence, Integer, Long, Integer, CharSequence, Integer, Boolean, Boolean, CharSequence, Boolean, Boolean, Boolean, Integer, Integer, StorePartitionerConfig, Integer, Integer, CharSequence, Boolean, Boolean, Boolean, StoreHybridConfig, Boolean, Boolean, Integer, DataRecoveryConfig, Boolean, Map<String, StoreViewConfig>) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreVersion
All-args constructor.
StoreVersionLifecycleEventOutcome - Enum in com.linkedin.venice.hooks
A hook which returns this enum has the option of proceeding, aborting, waiting or rolling back.
storeVersionPartitionCount - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
storeVersionState - Variable in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
Metadata for the version, including info like: sorted, chunked, compressionStrategy, TopicSwitch, etc
storeVersionState - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
StoreVersionState - Class in com.linkedin.venice.kafka.protocol.state
This record maintains store-version level state, such as the StartOfBufferReplay Control Message, in the case of Hybrid Stores.
StoreVersionState - Class in com.linkedin.venice.meta.systemstore.schemas
 
StoreVersionState() - Constructor for class com.linkedin.venice.kafka.protocol.state.StoreVersionState
Default constructor.
StoreVersionState() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
Default constructor.
StoreVersionState(Boolean, StartOfBufferReplay, Boolean, Integer, TopicSwitch, ByteBuffer, Integer, Long, Long) - Constructor for class com.linkedin.venice.kafka.protocol.state.StoreVersionState
All-args constructor.
StoreVersionState(Integer, CharSequence, Integer, Long, Boolean, CharSequence, Boolean, Boolean, CharSequence, Boolean, CharSequence, CharSequence, PartitionerConfig) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
All-args constructor.
StoreViewConfig - Class in com.linkedin.venice.systemstore.schemas
A configuration for a particular view.
StoreViewConfig() - Constructor for class com.linkedin.venice.systemstore.schemas.StoreViewConfig
Default constructor.
StoreViewConfig(CharSequence, Map<String, CharSequence>) - Constructor for class com.linkedin.venice.systemstore.schemas.StoreViewConfig
All-args constructor.
StoreViewConfigRecord - Class in com.linkedin.venice.controller.kafka.protocol.admin
A configuration for a particular view.
StoreViewConfigRecord() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
Default constructor.
StoreViewConfigRecord(CharSequence, Map<String, CharSequence>) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
All-args constructor.
StoreViewUtils - Class in com.linkedin.venice.controller
 
StoreViewUtils() - Constructor for class com.linkedin.venice.controller.StoreViewUtils
 
StoreWriteComputeProcessor - Class in com.linkedin.davinci.kafka.consumer
This class handles Write Compute operations related to a specific store.
StoreWriteComputeProcessor(String, ReadOnlySchemaRepository, MergeRecordHelper, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.StoreWriteComputeProcessor
 
stream(Iterable<? extends T>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
stream(Iterator<? extends T>) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
stream(Iterator<T>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
stream(Spliterator<? extends T>, boolean) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
stream(T...) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
 
STREAM - com.linkedin.venice.meta.Version.PushType
 
STREAM_REPROCESSING - com.linkedin.venice.meta.Version.PushType
 
STREAM_REPROCESSING_TOPIC_SUFFIX - Static variable in interface com.linkedin.venice.meta.Version
 
STREAMING_FOOTER_SCHEMA_ID - Static variable in class com.linkedin.venice.streaming.StreamingConstants
 
streamingBatchGet(BatchGetRequestContext<K, V>, Set<K>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
streamingBatchGet(BatchGetRequestContext<K, V>, Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
 
streamingBatchGet(BatchGetRequestContext<K, V>, Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
This is the main implementation of the "streaming" version of batch get.
streamingBatchGet(BatchGetRequestContext<K, V>, Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
streamingBatchGet(BatchGetRequestContext<K, V>, Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.fastclient.RetriableAvroGenericStoreClient
 
streamingBatchGet(BatchGetRequestContext<K, V>, Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.fastclient.StatsAvroGenericStoreClient
 
streamingBatchGet(Set<K>) - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Get the values associated with the given keys and return them in a map of keys to values.
streamingBatchGet(Set<K>) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
streamingBatchGet(Set<K>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
streamingBatchGet(Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
streamingBatchGet(Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
streamingBatchGet(Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
streamingBatchGet(Set<K>, StreamingCallback<K, V>) - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
Streaming interface for AvroGenericStoreClient.batchGet(Set).
streamingBatchGet(Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
 
streamingBatchGet(Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
streamingBatchGet(Set<K>, StreamingCallback<K, V>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
 
StreamingCallback<K,​V> - Interface in com.linkedin.venice.client.store.streaming
 
StreamingCallback<T> - Interface in com.linkedin.venice.router.streaming
 
StreamingConstants - Class in com.linkedin.venice.streaming
 
streamingExecute(Set<K>) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
streamingExecute(Set<K>) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Send compute request to Venice, and this should be the last step of the compute specification.
streamingExecute(Set<K>, StreamingCallback<K, ComputeGenericRecord>) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
 
streamingExecute(Set<K>, StreamingCallback<K, ComputeGenericRecord>) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
Streaming interface for ComputeRequestBuilder.execute(Set), and you could find more info in StreamingCallback.
StreamingFooterRecordV1 - Class in com.linkedin.venice.read.protocol.response.streaming
This record will store all the additional info after sending out streaming response
StreamingFooterRecordV1() - Constructor for class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Default constructor.
StreamingFooterRecordV1(Integer, ByteBuffer, Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
All-args constructor.
StreamingUtils - Class in com.linkedin.venice.streaming
 
StreamingUtils() - Constructor for class com.linkedin.venice.streaming.StreamingUtils
 
streamOf(Iterable<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
streamOf(Iterator<T>) - Method in class com.linkedin.alpini.base.misc.Joiner
 
streamPost(String, Map<String, String>, byte[], TransportClientStreamingCallback, int) - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
streamPost(String, Map<String, String>, byte[], TransportClientStreamingCallback, int) - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
Leverage non-streaming post to achieve feature parity.
streamPost(String, Map<String, String>, byte[], TransportClientStreamingCallback, int) - Method in class com.linkedin.venice.client.store.transport.TransportClient
 
streamPost(String, Map<String, String>, byte[], TransportClientStreamingCallback, int) - Method in class com.linkedin.venice.fastclient.transport.InternalTransportClient
 
STRING - com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
string_field - Variable in class com.linkedin.venice.client.store.schemas.TestKeyRecord
 
string_field - Variable in class com.linkedin.venice.client.store.schemas.TestValueRecord
 
string_field - Variable in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
STRING_FORMAT - Static variable in class com.linkedin.venice.RequestConstants
 
STRING_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
STRING_TO_NAME_RECORD_V1_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
STRING_TO_NAME_RECORD_V1_UPDATE_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
STRING_TO_NAME_RECORD_V3_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
STRING_TO_STRING_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
STRING_TO_STRING_WITH_EXTRA_FIELD_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
StringAnnotatedStoreSchemaCache - Class in com.linkedin.davinci.replication.merge
This class serves as the annotated schema cache for merge conflict resolution purpose in Active/Active replication.
StringAnnotatedStoreSchemaCache(String, ReadOnlySchemaRepository) - Constructor for class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
 
stringBuilder() - Static method in class com.linkedin.alpini.base.misc.Msg
 
StringSerializer - Class in com.linkedin.venice.serialization
 
StringSerializer() - Constructor for class com.linkedin.venice.serialization.StringSerializer
 
StringToLongMapJSONSerializer - Class in com.linkedin.venice.controller.kafka.consumer
 
StringToLongMapJSONSerializer() - Constructor for class com.linkedin.venice.controller.kafka.consumer.StringToLongMapJSONSerializer
 
StripedAccumulator<A> - Class in com.linkedin.alpini.base.concurrency
 
stripFromUnion(Schema) - Static method in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
Deprecated.
 
StuckConsumerRepairStats - Class in com.linkedin.davinci.stats
 
StuckConsumerRepairStats(MetricsRepository) - Constructor for class com.linkedin.davinci.stats.StuckConsumerRepairStats
 
SUB_PARTITION_COUNT - Static variable in class com.linkedin.venice.views.ViewUtils
 
subList(int, int) - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
subList(int, int) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
 
submit(Runnable) - Method in interface com.linkedin.alpini.base.concurrency.ExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable) - Method in class com.linkedin.alpini.base.misc.ThreadPoolExecutor
 
submit(Runnable) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
 
submit(Runnable) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
submit(Runnable) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
submit(Runnable, T) - Method in interface com.linkedin.alpini.base.concurrency.ExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable, T) - Method in class com.linkedin.alpini.base.misc.ThreadPoolExecutor
 
submit(Runnable, T) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
 
submit(Runnable, T) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
submit(Runnable, T) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
submit(Callable<T>) - Method in interface com.linkedin.alpini.base.concurrency.ExecutorService
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Callable<T>) - Method in class com.linkedin.alpini.base.misc.ThreadPoolExecutor
 
submit(Callable<T>) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
 
submit(Callable<T>) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
submit(Callable<T>) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
subPartitionCount - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
This would be the number of partitions in the StorageEngine and in version topics
SubPartitionStatus - Enum in com.linkedin.venice.pushmonitor
SubPartitionStatus is an enum and is not related to { @link PartitionStatus }
subpoolCount() - Method in interface com.linkedin.alpini.netty4.pool.ChannelPoolManager
The number of subpool threads used per pool by this class.
subpoolCount() - Method in class com.linkedin.alpini.netty4.pool.ChannelPoolManagerImpl
 
subpoolCount() - Method in class com.linkedin.alpini.netty4.pool.SimpleChannelPoolManagerImpl
 
SubprocessBuilder - Class in com.linkedin.alpini.io
A proxy class for java.lang.ProcessBuilder which may be overridden for purposes of test.
SubprocessBuilder() - Constructor for class com.linkedin.alpini.io.SubprocessBuilder
 
subscribe(PubSubTopicPartition, long) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
Subscribe to a topic-partition if not already subscribed.
subscribe(PubSubTopicPartition, long) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Subscribes to a topic-partition if it is not already subscribed.
subscribe(PubSubTopicPartition, long) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
subscribe(ComplementSet<Integer>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
subscribe(ComplementSet<Integer>) - Method in class com.linkedin.davinci.StoreBackend
 
subscribe(String) - Method in class com.linkedin.davinci.repository.DaVinciClientMetaStoreBasedRepository
Deprecated.
 
subscribe(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
subscribe(String) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
 
subscribe(String) - Method in class com.linkedin.venice.helix.SubscriptionBasedStoreRepository
 
subscribe(String) - Method in interface com.linkedin.venice.meta.SubscriptionBasedReadOnlyStoreRepository
 
subscribe(String, T) - Method in class com.linkedin.venice.listener.ListenerManager
 
subscribe(Set<Integer>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
subscribe(Set<Integer>) - Method in interface com.linkedin.davinci.client.DaVinciClient
Ingest specific partition/partitions locally.
subscribe(Set<Integer>) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
subscribe(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Subscribe a set of partitions for a store to this VeniceChangelogConsumer.
subscribe(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
SUBSCRIBE - com.linkedin.davinci.kafka.consumer.ConsumerActionType
 
SUBSCRIBE_ACTION_PREP_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
subscribeAll() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
subscribeAll() - Method in interface com.linkedin.davinci.client.DaVinciClient
Ingest the entire data (i.e.
subscribeAll() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
subscribeAll() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Subscribe all partitions belonging to a specific store.
subscribeAll() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
subscribeConsumerFor(String, StoreIngestionTask, PubSubTopicPartition, long) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
subscribeDerivedSchemaCreationChange(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
subscribedStoreMap - Variable in class com.linkedin.davinci.repository.NativeMetadataRepository
 
subscribeKeySchemaCreationChange(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
subscribePartition(PubSubTopicPartition, Optional<LeaderFollowerStateType>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
subscribePartition(PubSubTopicPartition, Optional<LeaderFollowerStateType>, boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Adds an asynchronous partition subscription request for the task.
subscribePartitionStatusChange(OfflinePushStatus, PartitionStatusListener) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
subscribePartitionStatusChange(OfflinePushStatus, PartitionStatusListener) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Subscribe the data change of partition status.
subscribePushStatusCreationChange(IZkChildListener) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
subscribePushStatusCreationChange(IZkChildListener) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Subscribe a child listener that listens to OfflinePushStatus creation/deleted.
subscribeReplicationMetadataSchemaCreationChange(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
subscribeRouterCountChangedEvent(RoutersClusterManager.RouterCountChangedListener) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
subscribeRouterCountChangedEvent(RoutersClusterManager.RouterCountChangedListener) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Listen on the router count, get the notification once it's changed.
subscribeRoutingDataChange(String, RoutingDataRepository.RoutingDataChangedListener) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
subscribeRoutingDataChange(String, RoutingDataRepository.RoutingDataChangedListener) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Add a listener on kafka topic to get the notification when routing data is changed.
subscribeStoreConfigAddedOrDeletedListener(IZkChildListener) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
subscribeStoreConfigDataChangedListener(String, IZkDataListener) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
subscribeTopic(String, int) - Method in class com.linkedin.venice.pushmonitor.PushStatusCollector
 
subscribeValueSchemaCreationChange(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
SubscriptionBasedReadOnlyStoreRepository - Interface in com.linkedin.venice.meta
Interface defined subscription based readonly operations to access stores.
SubscriptionBasedStoreRepository - Class in com.linkedin.venice.helix
 
SubscriptionBasedStoreRepository(ZkClient, HelixAdapterSerializer, String) - Constructor for class com.linkedin.venice.helix.SubscriptionBasedStoreRepository
 
subSequence(int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Copies a range of characters into a new string.
subSequence(int, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Copies a range of characters into a new string.
subSequence(int, int) - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
subSequence(int, int, boolean) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Either copy or share a subset of underlying sub-sequence of bytes.
subSet(E, E) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
substituteEmptyMap(Map<K, V>) - Static method in class com.linkedin.venice.utils.CollectionUtils
This function can be useful when we want: - To ensure a map is not null.
substitutePartitionKey(VenicePath, RouterKey) - Method in class com.linkedin.venice.router.api.VenicePathParser
 
substitutePartitionKey(VenicePath, Collection<RouterKey>) - Method in class com.linkedin.venice.router.api.VenicePathParser
 
substitutePartitionKey(RouterKey) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
The following function is used to generate a VeniceMultiGetPath or a VeniceComputePath for a given key, and the generated VenicePath will be used to compose router request and forward to storage node; This function will be triggered by DDS router framework.
substitutePartitionKey(RouterKey) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
substitutePartitionKey(RouterKey) - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
For single-get request, the substituted request is same as the original request.
substitutePartitionKey(Collection<RouterKey>) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
The following function is used to generate a VeniceMultiGetPath or a VeniceComputePath for a given key subset, and the generated VenicePath will be used to compose router request and forward to storage node; This function will be triggered by DDS router framework.
substitutePartitionKey(Collection<RouterKey>) - Method in class com.linkedin.venice.router.api.path.VenicePath
 
substitutePartitionKey(Collection<RouterKey>) - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
substitutePartitionKey(P, Collection<K>) - Method in interface com.linkedin.alpini.router.api.ResourcePathParser
 
substitutePartitionKey(P, K) - Method in interface com.linkedin.alpini.router.api.ResourcePathParser
 
subType() - Method in interface com.linkedin.alpini.base.misc.HeaderUtils.ContentType
 
SUCCEEDED - com.linkedin.venice.hadoop.jobs.ComputeJob.Status
A job that has completed execution successfully
success(V) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
Create a new success future.
SUCCESS - com.linkedin.alpini.base.concurrency.AsyncFuture.Status
 
SUCCESS - com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
 
SUCCESS - com.linkedin.venice.status.protocol.enums.PushJobStatus
 
SUCCESS - com.linkedin.venice.utils.VeniceResourceCloseResult
 
SUCCESS_EXIT - com.linkedin.venice.samza.SamzaExitMode
Directly exit the Samza process with status code 0, which should be only used by stream reprocessing job; besides, status 0 will leave a green mark for Samza task, so this mode should be used when the stream reprocessing job succeeds.
SuccessAsyncFuture<T> - Class in com.linkedin.alpini.base.concurrency.impl
A simple implementation of AsyncFuture which behaves as if the Future has already completed successfully.
SuccessAsyncFuture(T) - Constructor for class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
Construct an AsyncFuture which is already in success state.
successfulLockAcquisition - Variable in class com.linkedin.venice.stats.VeniceLockStats
 
SuccessfulStreamingResponse - Class in com.linkedin.venice.router.streaming
Full response to indicate that all the sub responses are with good status: HttpResponseStatus.OK for streaming request.
SuccessfulStreamingResponse() - Constructor for class com.linkedin.venice.router.streaming.SuccessfulStreamingResponse
 
successRequest(ServerHttpRequestStats, double) - Method in class com.linkedin.venice.listener.ServerStatsContext
 
successString() - Method in class com.linkedin.venice.controller.AuditInfo
 
sumOffsetVector(Object) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
Returns a summation of all component parts to an offsetVector for vector comparison
SUPERSET_SCHEMA_CREATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
supersetSchema - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
superSetSchemaAutoGenerationForReadComputeEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
SupersetSchemaCreation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
SupersetSchemaCreation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
Default constructor.
SupersetSchemaCreation(CharSequence, CharSequence, SchemaMeta, Integer, SchemaMeta, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
All-args constructor.
SupersetSchemaGenerator - Interface in com.linkedin.venice.controller.supersetschema
 
SupersetSchemaGeneratorWithCustomProp - Class in com.linkedin.venice.controller.supersetschema
This class would copy the specified SupersetSchemaGeneratorWithCustomProp.customProp from the latest value schema to the generated superset schema and in the meantime, the compare method in this impl will consider this extra property as well.
SupersetSchemaGeneratorWithCustomProp(String) - Constructor for class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
 
supersetSchemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
SUPPRESS_END_OF_PUSH_MESSAGE - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
This config is a boolean which suppresses submitting the end of push message after data has been sent and does not poll for the status of the job to complete.
SUPPRESS_SYSTEM_EXIT - Static variable in class com.linkedin.venice.utils.Utils
 
suppressEndOfPushMessage - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
suppressLogs(boolean) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
switchToNewTopic(PubSubTopic, String, Integer) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
switchToRealTimeTopic(String, String, Store, String, List<String>) - Method in class com.linkedin.venice.ingestion.control.RealTimeTopicSwitcher
 
sync() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
sync() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Sync current database.
sync() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
sync() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
sync() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
sync() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
sync() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
Closes currentSSTFileWriter, update lastCheckPointedSSTFileNum with the current SST file number, validates checksum on this SST file and return updated checkpointingInfo with this lastCheckPointedSSTFileNum.
sync() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
sync() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
sync() - Method in class io.netty.bootstrap.PendingConnectPromise
 
sync(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
syncConsumedUpstreamRTOffsetMapIfNeeded(PartitionConsumptionState, Map<String, Long>) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
SyncResourceRegistry - Class in com.linkedin.alpini.base.registry
 
SyncResourceRegistry() - Constructor for class com.linkedin.alpini.base.registry.SyncResourceRegistry
Construct a ResourceRegistry class instance.
SyncResourceRegistry(boolean) - Constructor for class com.linkedin.alpini.base.registry.SyncResourceRegistry
Construct a ResourceRegistry class instance.
SyncShutdownable - Interface in com.linkedin.alpini.base.registry
 
SyncShutdownableAdapter - Class in com.linkedin.alpini.base.registry
 
syncTopicPartitionOffset(String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
Updates offset metadata and sync to storage for specified topic partition.
syncTopicSwitchToIngestionMetadataService(TopicSwitch, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
syncUninterruptibly() - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
syncUninterruptibly() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
syncUninterruptibly() - Method in class io.netty.bootstrap.PendingConnectPromise
 
syncWithDB() - Method in class com.linkedin.davinci.utils.StoragePartitionDiskUsage
sync with real partition DB usage and reset in memory partition usage to be zero
system(ZoneId) - Static method in enum com.linkedin.alpini.base.misc.Time
Obtains a clock that returns the current instant using best available system clock.
SYSTEM - com.linkedin.venice.meta.VeniceUserStoreType
These stores are system stores whose name starts with Store.SYSTEM_STORE_NAME_PREFIX.
SYSTEM_PROPERTY_FOR_APP_RUNNING_REGION - Static variable in class com.linkedin.venice.VeniceConstants
 
SYSTEM_SCHEMA_CLUSTER_D2_SERVICE_NAME - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SYSTEM_SCHEMA_CLUSTER_D2_ZK_HOST - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SYSTEM_SCHEMA_CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
The name of the cluster that should host the special stores used to serve system schemas.
SYSTEM_SCHEMA_INITIALIZATION_AT_START_TIME_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
Whether to initialize system schemas when controller starts.
SYSTEM_SCHEMA_READER_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
SYSTEM_STORE_FORMAT - Static variable in interface com.linkedin.venice.meta.Store
 
SYSTEM_STORE_NAME_PREFIX - Static variable in interface com.linkedin.venice.meta.Store
 
SYSTEM_STORE_OWNER - Static variable in class com.linkedin.venice.VeniceConstants
Used as the owner property of system stores which are internal to Venice.
SYSTEM_STORE_REPAIR_JOB_PREFIX - Static variable in class com.linkedin.venice.controller.systemstore.SystemStoreRepairTask
 
SYSTEM_STORE_TYPE - com.linkedin.venice.Arg
 
systemDefaultZone() - Static method in enum com.linkedin.alpini.base.misc.Time
Obtains a clock that returns the current instant using the best available system clock, converting to date and time using the default time-zone.
systemGetAllByName(String) - Method in class com.linkedin.venice.httpclient.CachedDnsResolver
 
SYSTEMS_PREFIX - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
systemSchemaClusterD2ServiceName - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
systemSchemaClusterD2ZKHost - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
SystemSchemaInitializationRoutine - Class in com.linkedin.venice.controller.init
 
SystemSchemaInitializationRoutine(AvroProtocolDefinition, VeniceControllerMultiClusterConfig, VeniceHelixAdmin) - Constructor for class com.linkedin.venice.controller.init.SystemSchemaInitializationRoutine
 
SystemSchemaInitializationRoutine(AvroProtocolDefinition, VeniceControllerMultiClusterConfig, VeniceHelixAdmin, Optional<Schema>, Optional<UpdateStoreQueryParams>, boolean) - Constructor for class com.linkedin.venice.controller.init.SystemSchemaInitializationRoutine
 
systemStore - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
SystemStore - Class in com.linkedin.venice.meta
This SystemStore class is a wrapper of the corresponding zk shared system store and the regular venice store to provide the exact same interface as the regular Venice Store for System Stores.
SystemStore(Store, VeniceSystemStoreType, Store) - Constructor for class com.linkedin.venice.meta.SystemStore
 
SystemStoreAclSynchronizationTask - Class in com.linkedin.venice.controller.authorization
Currently, acl creation is still managed by Nuage but Nuage is not aware about the system stores.
SystemStoreAclSynchronizationTask(AuthorizerService, VeniceParentHelixAdmin, long) - Constructor for class com.linkedin.venice.controller.authorization.SystemStoreAclSynchronizationTask
 
SystemStoreAttributes - Interface in com.linkedin.venice.meta
 
SystemStoreAttributesImpl - Class in com.linkedin.venice.meta
 
SystemStoreAttributesImpl() - Constructor for class com.linkedin.venice.meta.SystemStoreAttributesImpl
 
SystemStoreHealthCheckStats - Class in com.linkedin.venice.controller.stats
This class is the metric class for SystemStoreRepairService
SystemStoreHealthCheckStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
 
SystemStoreHeartbeatResponse - Class in com.linkedin.venice.controllerapi
 
SystemStoreHeartbeatResponse() - Constructor for class com.linkedin.venice.controllerapi.SystemStoreHeartbeatResponse
 
SystemStoreInitializationHelper - Class in com.linkedin.venice.controller.init
This class contains the logic to set up system stores.
SystemStoreJSONSerializer - Class in com.linkedin.venice.helix
 
SystemStoreJSONSerializer() - Constructor for class com.linkedin.venice.helix.SystemStoreJSONSerializer
 
SystemStoreJSONSerializer.SystemStoreSerializerMixin - Class in com.linkedin.venice.helix
 
SystemStoreProperties - Class in com.linkedin.venice.systemstore.schemas
This type describes all the distinct properties
SystemStoreProperties() - Constructor for class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
Default constructor.
SystemStoreProperties(Integer, Integer, Long, List<StoreVersion>) - Constructor for class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
All-args constructor.
SystemStoreRepairService - Class in com.linkedin.venice.controller.systemstore
This class is the system store repair service in Venice parent controller.
SystemStoreRepairService(VeniceParentHelixAdmin, VeniceControllerMultiClusterConfig, MetricsRepository) - Constructor for class com.linkedin.venice.controller.systemstore.SystemStoreRepairService
 
SystemStoreRepairTask - Class in com.linkedin.venice.controller.systemstore
This class tries to scan all cluster which current parent controller is the leader controller.
SystemStoreRepairTask(VeniceParentHelixAdmin, Map<String, SystemStoreHealthCheckStats>, int, int, AtomicBoolean) - Constructor for class com.linkedin.venice.controller.systemstore.SystemStoreRepairTask
 
systemStores - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
This field is used to maintain a mapping between each type of system store and the corresponding distinct properties
SystemStoreSerializerMixin(ZKStore, VeniceSystemStoreType, ZKStore) - Constructor for class com.linkedin.venice.helix.SystemStoreJSONSerializer.SystemStoreSerializerMixin
 
SystemTime - Class in com.linkedin.venice.utils
Time implementation that just reads from the system clock
SystemTime() - Constructor for class com.linkedin.venice.utils.SystemTime
 
systemUTC() - Static method in enum com.linkedin.alpini.base.misc.Time
Obtains a clock that returns the current instant using the best available system clock, converting to date and time using the UTC time-zone.

T

tailSet(E) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
take() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentLinkedBlockingQueue
take() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
take() - Method in class com.linkedin.venice.router.throttle.PendingRequestThrottler
The following function will decrease the counter by 1 to recover the capacity.
TARGET_VERSION_STATES - com.linkedin.venice.common.StoreMetadataType
 
TARGETED_REGION_PUSH_ENABLED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config to enable single targeted region push mode in VPJ.
TARGETED_REGION_PUSH_LIST - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
This is experimental config to specify a list of regions used for targeted region push in VPJ.
TARGETED_REGIONS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
String representation of the list of regions that is separated by comma for targeted region push
targetedRegions - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
The list of regions that is separated by comma for targeted region push.
targetedRegions - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
targetVersionStates - Variable in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
An array of version states that should be bootstrapped in each fabric.
TargetVersionStates - Class in com.linkedin.venice.meta.systemstore.schemas
This type of store metadata contains the target version states announced by the parent controller leader for a given store that each fabric should be bootstrapping towards.
TargetVersionStates() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
Default constructor.
TargetVersionStates(List<StoreVersionState>) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
All-args constructor.
TASK_ID_NOT_SET - Static variable in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
 
TASK_READ_QUOTA_THROTTLE - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TaskParams(String, Command.Params) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskParams
 
TaskResult(Command.Result) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
 
tasks - Variable in class com.linkedin.venice.datarecovery.DataRecoveryWorker
 
TaskTracker - Interface in com.linkedin.venice.hadoop.task
An interface to report task health and track task progress for different execution engines
TehutiUtils - Class in com.linkedin.venice.stats
Utils for venice metrics
TehutiUtils() - Constructor for class com.linkedin.venice.stats.TehutiUtils
 
TehutiUtils.RatioStat - Class in com.linkedin.venice.stats
Generate a ratio stat that is based on two arbitrary Rate.
TehutiUtils.SimpleRatioStat - Class in com.linkedin.venice.stats
Generate a ratio stat that is based on two arbitrary MeasurableStat.
TELEMETRY_MESSAGE_INTERVAL - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
The interval of number of messages upon which certain info is printed in the reducer logs.
TEMP_DIR_PREFIX - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
TempFileSSLConfigurator - Class in com.linkedin.venice.hadoop.ssl
 
TempFileSSLConfigurator() - Constructor for class com.linkedin.venice.hadoop.ssl.TempFileSSLConfigurator
 
TERMINAL_STATE_TOPIC_CHECK_DELAY_MS - Static variable in class com.linkedin.venice.ConfigKeys
Delay between each cycle where the checker will iterate over existing topics that are yet to be truncated and poll their job status until they reach terminal state to ensure version topics in parent fabric are truncated in a timely manner.
TerminalStateTopicCheckerForParentController - Class in com.linkedin.venice.controller
A task that periodically polls the job state for existing version topics in the parent fabric.
TerminalStateTopicCheckerForParentController(VeniceParentHelixAdmin, HelixReadOnlyStoreConfigRepository, long) - Constructor for class com.linkedin.venice.controller.TerminalStateTopicCheckerForParentController
 
terminationFuture() - Method in class com.linkedin.alpini.netty4.misc.InstrumentibleEventExecutor
 
terminationFuture() - Method in class com.linkedin.alpini.netty4.misc.LocalThreadEventLoopGroup
 
terminationFuture() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
testAfterIdle(T) - Method in interface com.linkedin.alpini.base.pool.AsyncPool.LifeCycle
 
testAfterIdle(T) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleFilter
 
testAfterIdle(T) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
testAfterIdle(T) - Method in class com.linkedin.alpini.base.pool.impl.RateLimitedCreateLifeCycle
 
TestKeyRecord - Class in com.linkedin.venice.client.store.schemas
 
TestKeyRecord() - Constructor for class com.linkedin.venice.client.store.schemas.TestKeyRecord
 
TestMockTime - Class in com.linkedin.venice.utils
A Time implementation which abstracts logical time away from real time, so that it can be deterministically controlled.
TestMockTime() - Constructor for class com.linkedin.venice.utils.TestMockTime
 
TestMockTime(long) - Constructor for class com.linkedin.venice.utils.TestMockTime
 
testOnRelease(T) - Method in interface com.linkedin.alpini.base.pool.AsyncPool.LifeCycle
 
testOnRelease(T) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleFilter
 
testOnRelease(T) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleStatsCollector
 
testOnRelease(T) - Method in class com.linkedin.alpini.base.pool.impl.RateLimitedCreateLifeCycle
 
TestStoragePersonaUtils - Class in com.linkedin.venice.utils
 
TestStoragePersonaUtils() - Constructor for class com.linkedin.venice.utils.TestStoragePersonaUtils
 
TestUtil - Enum in com.linkedin.alpini.base.test
 
TestUtils - Class in com.linkedin.venice.utils
General-purpose utility functions for tests.
TestUtils() - Constructor for class com.linkedin.venice.utils.TestUtils
 
TestUtils.NonDeterministicAssertion - Interface in com.linkedin.venice.utils
 
TestValueRecord - Class in com.linkedin.venice.client.store.schemas
 
TestValueRecord() - Constructor for class com.linkedin.venice.client.store.schemas.TestValueRecord
 
TestValueRecordWithMoreFields - Class in com.linkedin.venice.client.store.schemas
 
TestValueRecordWithMoreFields() - Constructor for class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
 
TestWriteUtils - Class in com.linkedin.venice.utils
 
TestWriteUtils() - Constructor for class com.linkedin.venice.utils.TestWriteUtils
 
TestWriteUtils.TestRecordType - Enum in com.linkedin.venice.utils
 
TestWriteUtils.TestTargetedField - Enum in com.linkedin.venice.utils
 
TEXT_HTML - Static variable in class com.linkedin.venice.HttpConstants
 
TEXT_PLAIN - Static variable in class com.linkedin.venice.HttpConstants
 
thenAccept(Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenAccept(Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenAccept(Consumer<? super V>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenAcceptAsync(Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenAcceptAsync(Consumer<? super T>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenAcceptAsync(Consumer<? super T>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenAcceptAsync(Consumer<? super T>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenAcceptAsync(Consumer<? super V>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenAcceptAsync(Consumer<? super V>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super V, ? super U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenApply(Function<? super T, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenApply(Function<? super T, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenApply(Function<? super V, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenApplyAsync(Function<? super T, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenApplyAsync(Function<? super T, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenApplyAsync(Function<? super V, ? extends U>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenApplyAsync(Function<? super V, ? extends U>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends W>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends W>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super V, ? super U, ? extends W>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenCompose(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenComposeAsync(Function<? super V, ? extends CompletionStage<U>>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenRun(Runnable) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenRun(Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenRun(Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenRunAsync(Runnable) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenRunAsync(Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenRunAsync(Runnable) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
thenRunAsync(Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
thenRunAsync(Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
thenRunAsync(Runnable, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
THIN_CLIENT_BASED_METADATA - com.linkedin.venice.fastclient.meta.StoreMetadataFetchMode
Deprecated.
THIN_CLIENT_RETRY_BACKOFF_MS - Static variable in class com.linkedin.davinci.repository.NativeMetadataRepository
 
THIN_CLIENT_RETRY_COUNT - Static variable in class com.linkedin.davinci.repository.NativeMetadataRepository
 
ThinClientBasedMetadata - Class in com.linkedin.venice.fastclient.meta
An implementation of the VeniceClientBasedMetadata that uses a Venice thin client to refresh the local metadata cache periodically.
ThinClientBasedMetadata(ClientConfig, AvroSpecificStoreClient<StoreMetaKey, StoreMetaValue>) - Constructor for class com.linkedin.venice.fastclient.meta.ThinClientBasedMetadata
 
ThinClientMetaStoreBasedRepository - Class in com.linkedin.davinci.repository
 
ThinClientMetaStoreBasedRepository(ClientConfig, VeniceProperties, ICProvider) - Constructor for class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
 
thisIsLocalhost() - Static method in class com.linkedin.venice.utils.Utils
The ssl certificate we have for unit tests has the hostname "localhost".
THREADED - com.linkedin.alpini.base.concurrency.ConcurrentAccumulator.Mode
 
ThreadedAccumulator<T,​A,​R> - Class in com.linkedin.alpini.base.concurrency
 
threadFactory(ThreadFactory) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
threadFactory(ThreadFactory) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
ThreadPoolExecutor - Class in com.linkedin.alpini.base.misc
An ExecutorService that executes each submitted task using one of possibly several pooled threads, normally configured using Executors factory methods.
ThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>) - Constructor for class com.linkedin.alpini.base.misc.ThreadPoolExecutor
Creates a new ThreadPoolExecutor with the given initial parameters and default thread factory and rejected execution handler.
ThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class com.linkedin.alpini.base.misc.ThreadPoolExecutor
Creates a new ThreadPoolExecutor with the given initial parameters and default thread factory.
ThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class com.linkedin.alpini.base.misc.ThreadPoolExecutor
Creates a new ThreadPoolExecutor with the given initial parameters and default rejected execution handler.
ThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class com.linkedin.alpini.base.misc.ThreadPoolExecutor
Creates a new ThreadPoolExecutor with the given initial parameters.
ThreadPoolFactory - Class in com.linkedin.venice.utils.concurrent
 
ThreadPoolStats - Class in com.linkedin.venice.stats
Stats used to collect the usage of a thread pool including: 1.
ThreadPoolStats(MetricsRepository, ThreadPoolExecutor, String) - Constructor for class com.linkedin.venice.stats.ThreadPoolStats
 
Threadsafe - Annotation Type in com.linkedin.venice.annotation
Claims that a class is threadsafe or admonishes implementors of an interface to ensure that their implementation is threadsafe.
threadToThrowableToString(Thread) - Static method in class com.linkedin.venice.utils.ExceptionUtils
 
ThreadUtils - Class in com.linkedin.alpini.jna
 
ThreadUtils.DarwinCLib - Interface in com.linkedin.alpini.jna
 
ThreadUtils.LinuxCLib - Interface in com.linkedin.alpini.jna
 
ThreadUtils.OsPlatform - Enum in com.linkedin.alpini.jna
 
ThreadUtils.WindowsCLib - Interface in com.linkedin.alpini.jna
 
threeBoolean() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
throttle() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSink
 
THROTTLE_HANDLER_BYTE_ATTRIBUTE_KEY - Static variable in class com.linkedin.venice.router.RouterThrottleHandler
 
throttledOpen(String, RocksDBThrottler.RocksDBSupplier) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBThrottler
 
THROW_ERROR_EXCEPTION - com.linkedin.venice.samza.SamzaExitMode
Stop the Samza task by keep throwing exception.
throwException(Throwable) - Method in interface com.linkedin.alpini.base.misc.ExceptionUtil.ExceptionThrower
 
throwException(Throwable) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
 
throwException(Throwable) - Method in class com.linkedin.alpini.base.misc.Netty4ThrowException
 
throwIfNotReady() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
throwIfNotRunning() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
throwing(Level, T) - Method in class com.linkedin.alpini.log.FastLogger
 
throwing(T) - Method in class com.linkedin.alpini.log.FastLogger
 
throwOrLogStorageFailureDependingIfStillSubscribed(int, VeniceException) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
Time - Enum in com.linkedin.alpini.base.misc
Utility methods for time travelling and freezing time.
Time - Interface in com.linkedin.venice.utils
The interface to time itself.
TIME_LAG - com.linkedin.davinci.ingestion.LagType
 
TIME_LAG_TO_GO_ONLINE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
Time.Awaitable - Interface in com.linkedin.alpini.base.misc
 
TimeFormat - Enum in com.linkedin.alpini.base.misc
This utility class provides methods to format and parse a timespan in a human readable form.
timeout(CHC, Runnable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
timeout(CHC, String, AsyncPromise<Void>) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
timeout(CHC, String, AsyncPromise<T>, T) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
timeout(ChannelHandlerContext, Runnable) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
timeoutProcessor(TimeoutProcessor) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
timeoutProcessor(RouterTimeoutProcessor) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
timeoutProcessor(RouterTimeoutProcessor) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
TimeoutProcessor - Class in com.linkedin.alpini.base.concurrency
More efficient handling of cancellable schedulable events.
TimeoutProcessor() - Constructor for class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
TimeoutProcessor(ResourceRegistry) - Constructor for class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
TimeoutProcessor(ResourceRegistry, boolean, int) - Constructor for class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
TimeoutProcessor(ResourceRegistry, long, boolean, int) - Constructor for class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
TimeoutProcessor.TimeoutFuture - Class in com.linkedin.alpini.base.concurrency
 
Timer - Interface in com.linkedin.venice.utils
 
TimerTimeoutProcessor - Class in com.linkedin.alpini.router.impl.netty4
 
TimerTimeoutProcessor(Timer) - Constructor for class com.linkedin.alpini.router.impl.netty4.TimerTimeoutProcessor
 
TimeScheduledThreadPoolExecutor - Class in com.linkedin.alpini.base.misc
A ThreadPoolExecutor that can additionally schedule commands to run after a given delay, or to execute periodically.
TimeScheduledThreadPoolExecutor(int) - Constructor for class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Creates a new ScheduledThreadPoolExecutor with the given core pool size.
TimeScheduledThreadPoolExecutor(int, RejectedExecutionHandler) - Constructor for class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Creates a new ScheduledThreadPoolExecutor with the given initial parameters.
TimeScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Creates a new ScheduledThreadPoolExecutor with the given initial parameters.
TimeScheduledThreadPoolExecutor(int, ThreadFactory, RejectedExecutionHandler) - Constructor for class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
Creates a new ScheduledThreadPoolExecutor with the given initial parameters.
timestamp - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
Timestamp when the value or a partial update for the value was generated by the writer (Venice controller).
timestamp - Variable in class com.linkedin.venice.participant.protocol.KillPushJob
 
timestamp - Variable in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
Epoch time of when a heartbeat is generated.
timestamp - Variable in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
timestamp - Variable in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
Timestamp when the value or a partial update for the value was generated by the writer (Venice Controller/Venice Server).
TIMESTAMP_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.RmdConstants
 
TIMESTAMP_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.RmdConstants
 
TIMESTAMP_REGRESSION_DCR_ERROR - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
timestampMetadataVersionId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
The A/A metadata schema version ID that will be used to deserialize metadataPayload.
timestampMetadataVersionId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
timestampMetadataVersionId - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
The A/A timestamp metadata schema version ID that will be used to deserialize metadataPayload.
timestampPolicy - Variable in class com.linkedin.venice.kafka.protocol.StartOfPush
The policy to determine timestamps of batch push records.
TimeValue - Class in com.linkedin.alpini.base.misc
A class to encapsulate time values along with their measurement units Works for both timestamps as well as time durations.
TimeValue() - Constructor for class com.linkedin.alpini.base.misc.TimeValue
 
TimeValue(long, TimeUnit) - Constructor for class com.linkedin.alpini.base.misc.TimeValue
 
toAlpiniSSLConfig(SSLConfig) - Static method in class com.linkedin.venice.utils.SslUtils
 
toAlpiniSSLFactory(SSLFactory) - Static method in class com.linkedin.venice.utils.SslUtils
 
toAlpiniSSLFactory(SSLFactory, boolean) - Static method in class com.linkedin.venice.utils.SslUtils
 
toArray() - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
toArray() - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
toArray() - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
toArray(T[]) - Method in class com.linkedin.alpini.base.concurrency.ArraySortedSet
 
toArray(T[]) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
toArray(T1[]) - Method in class com.linkedin.davinci.kafka.consumer.MemoryBoundBlockingQueue
 
toAsciiString() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
toBatch() - Method in class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputScan
 
toBuilder() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
toBuilder() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
toByteArray() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Converts this string to a byte array.
toByteArray() - Method in class com.linkedin.venice.compression.ReusableGzipOutputStream
 
toByteArray() - Method in class com.linkedin.venice.io.ZeroCopyByteArrayOutputStream
 
toByteArray(int, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Converts a subset of this string to a byte array.
toByteArray(InputStream) - Static method in enum com.linkedin.alpini.io.IOUtils
 
toByteArray(InputStream, byte[]) - Static method in enum com.linkedin.alpini.io.IOUtils
 
toByteBuffer() - Method in class com.linkedin.venice.io.ZeroCopyByteArrayOutputStream
 
toBytes() - Method in class com.linkedin.venice.offsets.OffsetRecord
serialize to bytes
toBytes(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
toBytes(Object, DataOutputStream) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
toCompletableFuture() - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
toCompletableFuture() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
 
toCompletableFuture() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
 
toDisplay() - Method in enum com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
 
toHexString(byte[]) - Static method in class com.linkedin.venice.utils.ByteUtils
Translate the given byte array into a hexadecimal string
toHexString(byte[], int, int) - Static method in class com.linkedin.venice.utils.ByteUtils
Translate the given byte array with specific start position and length into a hexadecimal string
toHexStrings(Iterable<ByteArray>) - Static method in class com.linkedin.venice.utils.ByteArray
Translate the each ByteArray in an iterable into a hexidecimal string
toHttp2Headers(ChannelHandlerContext, HttpMessage, boolean) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
 
toHttp2Headers(ChannelHandlerContext, HttpMessage, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http2StreamFrameClientCodec
 
toHttp2Headers(ChannelHandlerContext, HttpMessage, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http2StreamFrameServerCodec
 
toJsonString() - Method in class com.linkedin.venice.offsets.OffsetRecord
PartitionState will be encoded with an in-house JsonEncoder which would transfer all data with "bytes" schema to hexadecimal strings.
TokenBucket - Class in com.linkedin.venice.throttle
 
TokenBucket(long, long, long, TimeUnit) - Constructor for class com.linkedin.venice.throttle.TokenBucket
 
TokenBucket(long, long, long, TimeUnit, Clock) - Constructor for class com.linkedin.venice.throttle.TokenBucket
This constructor should only be used by tests.
toList() - Method in class com.linkedin.venice.pubsub.api.EmptyPubSubMessageHeaders
 
toList() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
 
toList(Iterator<T>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
 
toLowerCase() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Converts the characters in this string to lowercase, using the default Locale.
toLowerCase(CharSequence) - Static method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
TOMBSTONE_CREATION_DCR - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
toMultiGetPath() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
 
TOO_MANY_REQUESTS - Static variable in class com.linkedin.venice.grpc.GrpcErrorCodes
 
toObject(byte[]) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
tooManyRequests() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
tooManyRequests() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
tooManyStreamsException(String) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Creates an Http2Exception for having too many concurrent requests.
TooManyWaitersException() - Constructor for exception com.linkedin.alpini.base.pool.impl.AsyncPoolImpl.TooManyWaitersException
 
TOP_LEVEL_COLO_ID_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
TOP_LEVEL_COLO_ID_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
TOP_LEVEL_TS_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
TOP_LEVEL_TS_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
topic - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
topic - Variable in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter.SendMessageParameters
 
topic() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionInfo
 
TOPIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
TOPIC_CLEANUP_DELAY_FACTOR - Static variable in class com.linkedin.venice.ConfigKeys
 
TOPIC_CLEANUP_SEND_CONCURRENT_DELETES_REQUESTS - Static variable in class com.linkedin.venice.ConfigKeys
 
TOPIC_CLEANUP_SLEEP_INTERVAL_BETWEEN_TOPIC_LIST_FETCH_MS - Static variable in class com.linkedin.venice.ConfigKeys
Sleep interval between each topic list fetch from Kafka ZK in TopicCleanup service.
TOPIC_COMPACTION_POLICY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
TOPIC_CREATED - com.linkedin.venice.status.PushJobDetailsStatus
 
TOPIC_CREATION_THROTTLING_TIME_WINDOW_MS - Static variable in class com.linkedin.venice.ConfigKeys
The time window in ms used to throttle the Kafka topic creation, during the time window, only 1 topic is allowed to be created.
TOPIC_DELETION_STATUS_POLL_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
Sleep interval for polling topic deletion status from ZK.
TOPIC_MANAGER_KAFKA_OPERATION_TIMEOUT_MS - Static variable in class com.linkedin.venice.ConfigKeys
Timeout for create topic and delete topic operations.
TOPIC_PARTITION_INGESTION_CONTEXT - com.linkedin.venice.meta.QueryAction
 
TOPIC_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
TOPIC_SWITCH - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
TOPIC_SWITCH_RECEIVED - com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
 
TOPIC_SWITCH_RECEIVED - com.linkedin.venice.pushmonitor.ExecutionStatus
Tasks belonging to a Hybrid Store emits this instead when it consumes a TS message
TOPIC_SWITCH_RECEIVED - com.linkedin.venice.pushmonitor.SubPartitionStatus
 
TOPIC_WISE_SHARED_CONSUMER_ASSIGNMENT_STRATEGY - com.linkedin.davinci.kafka.consumer.KafkaConsumerService.ConsumerAssignmentStrategy
 
TopicCleanupService - Class in com.linkedin.venice.controller.kafka
The topic cleanup in Venice adopts the following strategy: 1.
TopicCleanupService(Admin, VeniceControllerMultiClusterConfig, PubSubTopicRepository, TopicCleanupServiceStats) - Constructor for class com.linkedin.venice.controller.kafka.TopicCleanupService
 
TopicCleanupServiceForParentController - Class in com.linkedin.venice.controller.kafka
In parent controller, TopicCleanupServiceForParentController will remove all the deprecated topics: topic with low retention policy.
TopicCleanupServiceForParentController(Admin, VeniceControllerMultiClusterConfig, PubSubTopicRepository, TopicCleanupServiceStats) - Constructor for class com.linkedin.venice.controller.kafka.TopicCleanupServiceForParentController
 
TopicCleanupServiceStats - Class in com.linkedin.venice.controller.stats
 
TopicCleanupServiceStats(MetricsRepository) - Constructor for class com.linkedin.venice.controller.stats.TopicCleanupServiceStats
 
topicCleanupWhenPushComplete(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
In this function, Controller will setup proper compaction strategy when the push job is full completed, and here are the reasons to set it up after the job completes: 1.
topicCleanupWhenPushComplete(String, String, int) - Method in interface com.linkedin.venice.meta.StoreCleaner
This purpose of this function is to execute some topic related cleanup when push job is completed.
topicCompressionStrategy - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
TopicExistenceChecker - Interface in com.linkedin.davinci.kafka.consumer
 
TopicManager - Class in com.linkedin.venice.pubsub.manager
Topic manager is responsible for creating, deleting, and updating topics.
TopicManager(String, TopicManagerContext) - Constructor for class com.linkedin.venice.pubsub.manager.TopicManager
 
TopicManagerContext - Class in com.linkedin.venice.pubsub.manager
A context object that contains all the dependencies needed by TopicManager.
TopicManagerContext.Builder - Class in com.linkedin.venice.pubsub.manager
 
TopicManagerContext.PubSubPropertiesSupplier - Interface in com.linkedin.venice.pubsub.manager
 
topicManagerRepository - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
TopicManagerRepository - Class in com.linkedin.venice.pubsub.manager
A repository of TopicManager instances, each associated with a specific PubSub region and cluster.
TopicManagerRepository(TopicManagerContext, String) - Constructor for class com.linkedin.venice.pubsub.manager.TopicManagerRepository
 
TopicMessageFinder - Class in com.linkedin.venice
This class is used to find messages for a given key from a specified topic.
TopicMessageFinder() - Constructor for class com.linkedin.venice.TopicMessageFinder
 
topicName - Variable in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
topicName - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
topicName - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
topicName - Variable in class com.linkedin.venice.writer.AbstractVeniceWriter
 
TopicPartitionConsumerFunction - Interface in com.linkedin.davinci.kafka.consumer
 
topicPartitionHasAnyPendingActions(String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
TopicPartitionIngestionContextRequest - Class in com.linkedin.venice.listener.request
 
TopicPartitionIngestionContextResponse - Class in com.linkedin.davinci.listener.response
 
TopicPartitionIngestionContextResponse() - Constructor for class com.linkedin.davinci.listener.response.TopicPartitionIngestionContextResponse
 
TopicPartitionIngestionInfo - Class in com.linkedin.davinci.kafka.consumer
 
TopicPartitionIngestionInfo(long, long, double, double, int, long) - Constructor for class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
 
TopicPartitionsOffsetsTracker - Class in com.linkedin.venice.pubsub.adapter.kafka
This class tracks consumed topic partitions' offsets
TopicPartitionsOffsetsTracker() - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
 
topicSwitch - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
If a TopicSwitch has been consumed, then it is stored in its entirety here, otherwise, this field is null.
TopicSwitch - Class in com.linkedin.venice.kafka.protocol
This ControlMessage is sent by the Controller, once per partition; it will only be used in leader/follower state transition model; this control message will indicate the leader to switch to a new source topic and start consuming from offset with a specific timestamp.
TopicSwitch() - Constructor for class com.linkedin.venice.kafka.protocol.TopicSwitch
Default constructor.
TopicSwitch(List<CharSequence>, CharSequence, Long) - Constructor for class com.linkedin.venice.kafka.protocol.TopicSwitch
All-args constructor.
topicSwitchReceived(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
The ControlMessageType.TOPIC_SWITCH control message was consumed.
topicSwitchReceived(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
 
topicSwitchReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
 
topicSwitchReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
 
topicSwitchReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
 
topicSwitchReceived(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
 
TopicSwitchWrapper - Class in com.linkedin.davinci.kafka.consumer
This class precomputes the conversion from Avro's CharSequence to String, and also hangs on to the correct instance of PubSubTopic, so that the lookup need not be performed in many locations.
TopicSwitchWrapper(TopicSwitch, PubSubTopic) - Constructor for class com.linkedin.davinci.kafka.consumer.TopicSwitchWrapper
 
TopicWiseKafkaConsumerService - Class in com.linkedin.davinci.kafka.consumer
TopicWiseKafkaConsumerService is used to allocate share consumer from consumer pool at topic granularity.
TOPOLOGY_CONSTRAINT - Static variable in class com.linkedin.venice.utils.HelixUtils
The constraint that helix would apply on CRUSH alg.
toProperties() - Method in class com.linkedin.venice.utils.VeniceProperties
 
toSimplifiedString() - Method in class com.linkedin.venice.offsets.OffsetRecord
This function will print only the critical info inside OffsetRecord, like offset, EOP received; producer DIV info will not be printed.
toSSLFactoryWithOpenSSLSupport(SSLFactory) - Static method in class com.linkedin.venice.utils.SslUtils
Adapt the incoming SSLFactory into a new one backed by openssl if it is available.
toString() - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
Returns a string identifying this CompletableFutureTask, as well as its completion state.
toString() - Method in class com.linkedin.alpini.base.concurrency.ComplexAccumulator
Returns the String representation of the ComplexAccumulator.get().
toString() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
Returns the String representation of the ConcurrentAccumulator.get().
toString() - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor
 
toString() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Translates the entire byte string to a String.
toString() - Method in class com.linkedin.alpini.base.misc.LowerCaseAsciiCharSequence
 
toString() - Method in class com.linkedin.alpini.base.misc.Msg
 
toString() - Method in class com.linkedin.alpini.base.misc.Pair
Return a string representation of the Pair.
toString() - Method in class com.linkedin.alpini.base.misc.RetryCounter
 
toString() - Method in class com.linkedin.alpini.base.misc.TimeValue
Emits a json serialized string that represents this TimeValue.
toString() - Method in class com.linkedin.alpini.base.misc.TouchTimer
 
toString() - Method in class com.linkedin.alpini.base.queuing.QOSPolicy.Config
 
toString() - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
 
toString() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
 
toString() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
toString() - Method in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation.Quantile
 
toString() - Method in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation.Sample
 
toString() - Method in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation.Sample
 
toString() - Method in class com.linkedin.alpini.base.statistics.LongQuantileEstimation.Sample
 
toString() - Method in class com.linkedin.alpini.base.statistics.LongStatsLowQuantileImpl
 
toString() - Method in class com.linkedin.alpini.base.statistics.Welfords.Result
 
toString() - Method in class com.linkedin.alpini.consts.Level
 
toString() - Method in class com.linkedin.alpini.io.SubprocessBuilder
 
toString() - Method in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
 
toString() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
toString() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
toString() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
 
toString() - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
 
toString() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
 
toString() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
toString() - Method in class com.linkedin.davinci.client.DaVinciConfig
 
toString() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
 
toString() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
 
toString() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
 
toString() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
toString() - Method in class com.linkedin.davinci.kafka.consumer.StorePartitionDataReceiver
 
toString() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
 
toString() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
 
toString() - Method in class com.linkedin.davinci.store.record.ByteBufferValueRecord
 
toString() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
 
toString() - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns a string representation of this map.
toString() - Method in class com.linkedin.davinci.validation.PartitionTracker
 
toString() - Method in class com.linkedin.davinci.VersionBackend
 
toString() - Method in enum com.linkedin.venice.Arg
 
toString() - Method in class com.linkedin.venice.authorization.AceEntry
 
toString() - Method in class com.linkedin.venice.authorization.AclBinding
 
toString() - Method in class com.linkedin.venice.authorization.Principal
 
toString() - Method in class com.linkedin.venice.authorization.Resource
 
toString() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
toString() - Method in class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
 
toString() - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
 
toString() - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
 
toString() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
 
toString() - Method in enum com.linkedin.venice.Command
 
toString() - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
 
toString() - Method in class com.linkedin.venice.compute.CountOperator
 
toString() - Method in class com.linkedin.venice.compute.DotProductOperator
 
toString() - Method in class com.linkedin.venice.compute.HadamardProductOperator
 
toString() - Method in class com.linkedin.venice.controller.AuditInfo
 
toString() - Method in class com.linkedin.venice.controller.init.SystemSchemaInitializationRoutine
 
toString() - Method in class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
 
toString() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
toString() - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponseV2
Deprecated.
 
toString() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.MigrationPushStrategyResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.OwnerResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.PartitionResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.QueryParams
 
toString() - Method in class com.linkedin.venice.controllerapi.ReadyForDataRecoveryResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.SchemaResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.StorageEngineOverheadRatioResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.StoragePersonaResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.StoreMigrationResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.TrackableControllerResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
 
toString() - Method in class com.linkedin.venice.controllerapi.VersionResponse
 
toString() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
 
toString() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
 
toString() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
 
toString() - Method in class com.linkedin.venice.helix.Replica
 
toString() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
toString() - Method in enum com.linkedin.venice.kafka.validation.checksum.CheckSumType
 
toString() - Method in class com.linkedin.venice.kafka.validation.Segment
 
toString() - Method in class com.linkedin.venice.listener.grpc.VeniceReadServiceImpl
 
toString() - Method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
 
toString() - Method in class com.linkedin.venice.listener.request.MultiGetRouterRequestWrapper
 
toString() - Method in class com.linkedin.venice.message.KafkaKey
 
toString() - Method in class com.linkedin.venice.meta.Instance
 
toString() - Method in class com.linkedin.venice.meta.LiveClusterConfig
 
toString() - Method in class com.linkedin.venice.meta.Partition
 
toString() - Method in class com.linkedin.venice.meta.PartitionAssignment
 
toString() - Method in class com.linkedin.venice.meta.PartitionDetail
 
toString() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
 
toString() - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
toString() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
toString() - Method in class com.linkedin.venice.meta.ReplicaDetail
 
toString() - Method in class com.linkedin.venice.meta.StoreDataAudit
 
toString() - Method in class com.linkedin.venice.meta.UncompletedPartition
 
toString() - Method in class com.linkedin.venice.meta.UncompletedReplica
 
toString() - Method in class com.linkedin.venice.meta.VersionImpl
 
toString() - Method in class com.linkedin.venice.offsets.OffsetRecord
 
toString() - Method in class com.linkedin.venice.persona.StoragePersona
 
toString() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
 
toString() - Method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaOffsetPosition
 
toString() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
 
toString() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
 
toString() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
 
toString() - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
toString() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
 
toString() - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
 
toString() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
 
toString() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
 
toString() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionInfo
 
toString() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
toString() - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
 
toString() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
toString() - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
toString() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
 
toString() - Method in class com.linkedin.venice.router.api.RouterKey
 
toString() - Method in enum com.linkedin.venice.router.api.RouterResourceType
 
toString() - Method in class com.linkedin.venice.routerapi.ReplicaState
 
toString() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
toString() - Method in class com.linkedin.venice.schema.GeneratedSchemaEntry
 
toString() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
 
toString() - Method in class com.linkedin.venice.schema.SchemaEntry
 
toString() - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
toString() - Method in class com.linkedin.venice.status.StoreStatusMessage
 
toString() - Method in class com.linkedin.venice.unit.matchers.LongEqualOrGreaterThanMatcher
 
toString() - Method in class com.linkedin.venice.utils.ByteArray
 
toString() - Method in class com.linkedin.venice.utils.collections.ArrayCollection
 
toString() - Method in class com.linkedin.venice.utils.ComplementSet
 
toString() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
 
toString() - Method in class com.linkedin.venice.utils.Pair
Deprecated.
 
toString() - Method in class com.linkedin.venice.utils.VeniceProperties
 
toString() - Method in class com.linkedin.venice.writer.VeniceWriter
 
toString() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
 
toString(boolean) - Method in class com.linkedin.venice.schema.SchemaEntry
 
toString(boolean) - Method in class com.linkedin.venice.utils.VeniceProperties
 
toString(int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Translates the entire byte string to a String using the charset encoding.
toString(int, int) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Translates the [start, end) range of this byte string to a String.
toString(InputStream, Charset) - Static method in enum com.linkedin.alpini.io.IOUtils
 
toString(InputStream, Charset, char[]) - Static method in enum com.linkedin.alpini.io.IOUtils
 
toString(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
Deprecated.
 
toString(UnaryOperator<StringBuilder>) - Static method in class com.linkedin.alpini.base.misc.Msg
 
TOTAL_DCR - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
TOTAL_GZIP_COMPRESSED_VALUE_SIZE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
TOTAL_KEY_SIZE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
TOTAL_PUT_OR_DELETE_COUNT_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
TOTAL_UNCOMPRESSED_VALUE_SIZE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
TOTAL_VALUE_SIZE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
TOTAL_ZSTD_WITH_DICT_COMPRESSED_VALUE_SIZE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
totalCompressedValueBytes - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
total amount of compressed value bytes stored
totalGzipCompressedValueBytes - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
total amount of Gzip compressed value bytes
totalKeyBytes - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
total amount of key bytes pushed
totalKeySizeCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
totalNumberOfRecords - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
total number of key value pairs pushed
totalQueues() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocatorMetric
 
totalRawValueBytes - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
total amount of uncompressed value bytes
totalReferences() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocatorMetric
 
totalStats - Variable in class com.linkedin.venice.stats.AbstractVeniceAggStats
 
totalZstdWithDictCompressedValueBytes - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
total amount of Zstd with Dictionary compressed value bytes
touch() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
touch() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
touch() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
touch() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
touch() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
touch() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
touch() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
touch() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
touch(Class<?>, String) - Method in class com.linkedin.alpini.base.misc.TouchTimer
Add an event to this timer.
touch(Class<?>, String, Object...) - Method in class com.linkedin.alpini.base.misc.TouchTimer
Add an event to this timer.
touch(Object) - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
 
touch(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
 
touch(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
touch(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
touch(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
touch(Object) - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
touch(Object) - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
 
touch(Object) - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
 
touch(String) - Method in class com.linkedin.alpini.base.misc.TouchTimer
Add an event to this timer.
touch(String, Object...) - Method in class com.linkedin.alpini.base.misc.TouchTimer
Add an event to this timer.
TouchTimer - Class in com.linkedin.alpini.base.misc
Handy utility class to track the timing while processing a request.
TouchTimer() - Constructor for class com.linkedin.alpini.base.misc.TouchTimer
Default constructor
TouchTimer(int) - Constructor for class com.linkedin.alpini.base.misc.TouchTimer
Alternative constructor
TouchTimer(long, long, int) - Constructor for class com.linkedin.alpini.base.misc.TouchTimer
 
TouchTimer.Visitor - Interface in com.linkedin.alpini.base.misc
Message Visitor interface
toUpperCase() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Converts the characters in this string to uppercase, using the default Locale.
trace(CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Message) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
trace(Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
TRACE - com.linkedin.venice.authorization.Method
 
TRACE - Static variable in class com.linkedin.alpini.consts.Level
The TRACE Level designates finer-grained informational events than the DEBUG level.
TRACE_INT - Static variable in class com.linkedin.alpini.consts.Level
 
traceEntry() - Method in class com.linkedin.alpini.log.FastLogger
 
traceEntry(String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
traceEntry(String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
traceEntry(Message) - Method in class com.linkedin.alpini.log.FastLogger
 
traceEntry(Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
traceExit() - Method in class com.linkedin.alpini.log.FastLogger
 
traceExit(String, R) - Method in class com.linkedin.alpini.log.FastLogger
 
traceExit(EntryMessage) - Method in class com.linkedin.alpini.log.FastLogger
 
traceExit(EntryMessage, R) - Method in class com.linkedin.alpini.log.FastLogger
 
traceExit(Message, R) - Method in class com.linkedin.alpini.log.FastLogger
 
traceExit(R) - Method in class com.linkedin.alpini.log.FastLogger
 
track(CompletableFuture<T>, ClientStats) - Static method in class com.linkedin.venice.client.store.AppTimeOutTrackingCompletableFuture
 
TrackableControllerResponse - Class in com.linkedin.venice.controllerapi
Extend this class to create response objects for async command.
TrackableControllerResponse() - Constructor for class com.linkedin.venice.controllerapi.TrackableControllerResponse
 
trackCall(long) - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
trackCall(long, TimeUnit) - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
trackCall(long, TimeUnit) - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
trackCallWithError(long) - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
trackCallWithError(long, Throwable) - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
trackCallWithError(long, TimeUnit) - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
trackCallWithError(long, TimeUnit, Throwable) - Method in interface com.linkedin.alpini.base.monitoring.CallTracker
 
trackCallWithError(long, TimeUnit, Throwable) - Method in class com.linkedin.alpini.base.monitoring.CallTrackerImpl
 
trackCallWithError(long, TimeUnit, Throwable) - Method in class com.linkedin.alpini.base.monitoring.NullCallTracker
 
trackCompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackCompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackCompressedValueSize(int) - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackDuplicateKeyWithDistinctValue(int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackDuplicateKeyWithDistinctValue(int) - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackDuplicateKeyWithDistinctValue(int) - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackDuplicateKeyWithIdenticalValue(int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackDuplicateKeyWithIdenticalValue(int) - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackDuplicateKeyWithIdenticalValue(int) - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackEmptyRecord() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackEmptyRecord() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackEmptyRecord() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackGzipCompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackGzipCompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackGzipCompressedValueSize(int) - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackHealthBasedOnRequestToInstance(String) - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
 
trackHealthBasedOnRequestToInstance(String, int, int, CompletableFuture<TransportClientResponse>) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
 
trackHealthBasedOnRequestToInstance(String, int, int, CompletableFuture<TransportClientResponse>) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
 
trackHealthBasedOnRequestToInstance(String, CompletableFuture<TransportClientResponse>) - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
This function tracks the health of an Instance based on the request sent to that Instance: by returning an incomplete completable future for AbstractStoreMetadata which 1.
TrackingStreamingCallback<K,​V> - Interface in com.linkedin.venice.client.store.streaming
This interface exposes one more function: TrackingStreamingCallback.onDeserializationCompletion(Optional, int, int), which will be used for metric tracking.
trackKeySize(int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackKeySize(int) - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackKeySize(int) - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackPartitionWriterClose() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackPartitionWriterClose() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackPartitionWriterClose() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackPutOrDeleteRecord() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackPutOrDeleteRecord() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackRecordSentToPubSub() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackRecordSentToPubSub() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackRecordSentToPubSub() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackRecordTooLargeFailure() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackRecordTooLargeFailure() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackRecordTooLargeFailure() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackRepushTtlFilteredRecord() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackRepushTtlFilteredRecord() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackRepushTtlFilteredRecord() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackSprayAllPartitions() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackSprayAllPartitions() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackSprayAllPartitions() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackUncompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackUncompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackUncompressedValueSize(int) - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackWriteAclAuthorizationFailure() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackWriteAclAuthorizationFailure() - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackWriteAclAuthorizationFailure() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trackZstdCompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
 
trackZstdCompressedValueSize(int) - Method in class com.linkedin.venice.hadoop.spark.datawriter.task.SparkDataWriterTaskTracker
 
trackZstdCompressedValueSize(int) - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
 
trailerHeaders - Variable in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
Additional headers after sending out response headers
trailingHeaders() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPartRequest
 
trailingHeaders() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
trailingHeaders() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
trailingHeaders() - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
trainDict() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputDictTrainer
 
trainZstdDictionary() - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
 
trainZstdDictionary() - Method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
 
trainZstdDictionary() - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
 
transform(String, KafkaKey, KafkaMessageEnvelope, int) - Method in interface com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter.SendMessageParametersTransformer
 
TRANSFORMER_ERROR_COUNT - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
TRANSFORMER_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
TransformingProducerAdapter - Class in com.linkedin.venice.unit.kafka.producer
This PubSubProducerAdapter implementation allows tests to perform arbitrary transformations on the messages that are about to be written to Kafka.
TransformingProducerAdapter(PubSubProducerAdapter, TransformingProducerAdapter.SendMessageParametersTransformer) - Constructor for class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
 
TransformingProducerAdapter.SendMessageParameters - Class in com.linkedin.venice.unit.kafka.producer
 
TransformingProducerAdapter.SendMessageParametersTransformer - Interface in com.linkedin.venice.unit.kafka.producer
 
transformValueSchemaForETL(Schema) - Static method in class com.linkedin.venice.etl.ETLUtils
Modify a store value schema to the value schema that can be used for ETL by allowing "null" values to be set
TransientRecord(byte[], int, int, int, int, long) - Constructor for class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
 
transmitVersionSwapMessage(Store, int, int) - Method in class com.linkedin.venice.ingestion.control.RealTimeTopicSwitcher
 
TransportClient - Class in com.linkedin.venice.client.store.transport
Define interfaces for TransportClient, and the target customer is the sub-classes of AvroGenericStoreClient
TransportClient() - Constructor for class com.linkedin.venice.client.store.transport.TransportClient
 
TransportClientCallback - Class in com.linkedin.venice.client.store.transport
Define the common functions for call back of TransportClient
TransportClientCallback(CompletableFuture<TransportClientResponse>) - Constructor for class com.linkedin.venice.client.store.transport.TransportClientCallback
 
TransportClientResponse - Class in com.linkedin.venice.client.store.transport
This class is used to capture the result returned by TransportClient
TransportClientResponse(int, CompressionStrategy, byte[]) - Constructor for class com.linkedin.venice.client.store.transport.TransportClientResponse
 
TransportClientResponseForRoute - Class in com.linkedin.venice.fastclient.transport
 
TransportClientResponseForRoute(String, int, CompressionStrategy, byte[], CompletableFuture<Integer>) - Constructor for class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
 
TransportClientStreamingCallback - Interface in com.linkedin.venice.client.store.transport
Callback to support streaming in TransportClient
TrieBasedPathResourceRegistry<T> - Class in com.linkedin.venice.utils
This class implements a generic trie-based lookup tree.
TrieBasedPathResourceRegistry() - Constructor for class com.linkedin.venice.utils.TrieBasedPathResourceRegistry
 
TriFunction<T,​U,​S,​R> - Interface in com.linkedin.alpini.base.misc
 
trigger(String, Consumer<T>) - Method in class com.linkedin.venice.listener.ListenerManager
Trigger notification and execute the given handler.
triggerRouterCountChangedEvent(int) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
trim() - Method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Duplicates this string removing white space characters from the beginning and end of the string, without copying.
trim(CharSequence) - Static method in class com.linkedin.alpini.base.misc.ByteBufAsciiString
Copies this string removing white space characters from the beginning and end of the string, and tries not to copy if possible.
TRUE - Static variable in interface com.linkedin.venice.utils.lazy.Lazy
 
trueAndFalseProvider() - Static method in class com.linkedin.venice.utils.DataProviderUtils
To use these data providers, add (dataProvider = "", dataProviderClass = DataProviderUtils.class) into the @Test annotation.
truncateKafkaTopic(String) - Method in interface com.linkedin.venice.controller.Admin
 
truncateKafkaTopic(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
We don't actually truncate any Kafka topic here; we just update the retention time.
truncateKafkaTopic(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
truncateKafkaTopic(String, long) - Method in interface com.linkedin.venice.controller.Admin
Truncate a Kafka topic by setting its retention time to the input value.
truncateKafkaTopic(String, long) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
truncateKafkaTopic(String, long) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
trustForwardHeaders(boolean) - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
 
tryConsume() - Method in class com.linkedin.venice.throttle.TokenBucket
 
tryConsume(long) - Method in class com.linkedin.venice.throttle.TokenBucket
 
tryDeserializeRecord(int) - Method in class com.linkedin.venice.client.store.streaming.ComputeResponseRecordV1ChunkedDeserializer
 
tryDeserializeRecord(int) - Method in class com.linkedin.venice.client.store.streaming.MultiGetResponseRecordV1ChunkedDeserializer
 
tryDeserializeRecord(int) - Method in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
All the derived class will implement this function to provide the customized logic to deserialize a record, and when hitting partial record, it should throw ReadEnvelopeChunkedDeserializer.NotEnoughBytesException.
tryFailure(Throwable) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
tryReadInt(int) - Method in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
The following implementation is equivalent to BinaryDecoder.readIndex()
trySuccess() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
trySuccess() - Method in class io.netty.bootstrap.PendingConnectPromise
 
trySuccess(V) - Method in class com.linkedin.alpini.base.misc.PromiseDelegate
 
tryToDeserializeWithVerboseLogging(RecordDeserializer<T>, ByteBuffer, int, K, RecordSerializer<K>, SchemaReader, Logger) - Static method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
TTLResolutionPolicy - Enum in com.linkedin.venice.hadoop.input.kafka.ttl
The policy controls the TTL behavior regarding how batch writes are treated.
twoBoolean() - Static method in class com.linkedin.venice.utils.DataProviderUtils
 
type - Variable in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
type of the position; 0 is reserved for Kafka offset (long), positive values are intended to be used for open-source pub-sub systems, and negative values are reserved for internal/proprietary pub-sub systems
type() - Method in interface com.linkedin.alpini.base.misc.HeaderUtils.ContentType
 
TYPE_ADMIN - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_ADMIN - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_ALL_VALUE_SCHEMA_IDS - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_ALL_VALUE_SCHEMA_IDS - Static variable in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
TYPE_CLUSTER_DISCOVERY - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_CLUSTER_DISCOVERY - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_COMPUTE - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_COMPUTE - Static variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
TYPE_COMPUTE - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_CURRENT_VERSION - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_CURRENT_VERSION - Static variable in class com.linkedin.venice.controller.StoreBackupVersionCleanupService
 
TYPE_CURRENT_VERSION - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_D2_SERVICE_DISCOVERY - Static variable in class com.linkedin.venice.client.store.D2ServiceDiscovery
 
TYPE_GET_UPDATE_SCHEMA - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_GET_UPDATE_SCHEMA - Static variable in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
TYPE_GET_UPDATE_SCHEMA - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_HEALTH_CHECK - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_INVALID - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_KEY_SCHEMA - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_KEY_SCHEMA - Static variable in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
TYPE_KEY_SCHEMA - Static variable in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
TYPE_KEY_SCHEMA - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_LATEST_VALUE_SCHEMA - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_LATEST_VALUE_SCHEMA - Static variable in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
TYPE_LEADER_CONTROLLER - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_LEADER_CONTROLLER - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_LEADER_CONTROLLER_LEGACY - com.linkedin.venice.router.api.RouterResourceType
Deprecated.
TYPE_LEADER_CONTROLLER_LEGACY - Static variable in class com.linkedin.venice.router.api.VenicePathParser
Deprecated.
TYPE_PUSH_STATUS - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_PUSH_STATUS - Static variable in class com.linkedin.venice.VeniceConstants
Beginning of router request path; it would used by router and client modules
TYPE_REQUEST_TOPIC - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_REQUEST_TOPIC - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_RESOURCE_STATE - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_RESOURCE_STATE - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_STORAGE - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_STORAGE - Static variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
 
TYPE_STORAGE - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TYPE_STORE_STATE - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_STORE_STATE - Static variable in class com.linkedin.venice.VeniceConstants
 
TYPE_STREAM_HYBRID_STORE_QUOTA - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_STREAM_HYBRID_STORE_QUOTA - Static variable in class com.linkedin.venice.VeniceConstants
 
TYPE_STREAM_REPROCESSING_HYBRID_STORE_QUOTA - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_STREAM_REPROCESSING_HYBRID_STORE_QUOTA - Static variable in class com.linkedin.venice.VeniceConstants
 
TYPE_UPDATE_SCHEMA - Static variable in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
TYPE_VALUE_SCHEMA - com.linkedin.venice.router.api.RouterResourceType
 
TYPE_VALUE_SCHEMA - Static variable in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
 
TYPE_VALUE_SCHEMA - Static variable in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
 
TYPE_VALUE_SCHEMA - Static variable in class com.linkedin.venice.router.api.VenicePathParser
 
TypedFieldAccessor<T,​V> - Interface in com.linkedin.alpini.base.misc
Interface for a generic typed field accessor.
TypedFieldAccessorHelper - Class in com.linkedin.alpini.base.misc
Helper class to determine at run time which implementation to use.
TypedFieldAccessorHelper() - Constructor for class com.linkedin.alpini.base.misc.TypedFieldAccessorHelper
 

U

UNAVAILABLE - com.linkedin.venice.meta.StoreStatus
 
unAvailableToZero(double) - Static method in class com.linkedin.davinci.stats.IngestionStats
 
unblock() - Method in class com.linkedin.alpini.base.concurrency.BlockingLatch
 
UncompletedPartition - Class in com.linkedin.venice.meta
 
UncompletedPartition() - Constructor for class com.linkedin.venice.meta.UncompletedPartition
 
UncompletedPartition(int, List<UncompletedReplica>) - Constructor for class com.linkedin.venice.meta.UncompletedPartition
 
UncompletedReplica - Class in com.linkedin.venice.meta
 
UncompletedReplica() - Constructor for class com.linkedin.venice.meta.UncompletedReplica
 
UncompletedReplica(String, ExecutionStatus, long, String) - Constructor for class com.linkedin.venice.meta.UncompletedReplica
 
uncompressedValueSizeCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
unconfigurableExecutorService(ExecutorService) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns an object that delegates all defined ExecutorService methods to the given executor, but not any other methods that might otherwise be accessible using casts.
unconfigurableScheduledExecutorService(ScheduledExecutorService) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns an object that delegates all defined ScheduledExecutorService methods to the given executor, but not any other methods that might otherwise be accessible using casts.
UNCREATED_VERSION_NUMBER - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Placeholder for version number that is yet to be created.
UndefinedPropertyException - Exception in com.linkedin.venice.exceptions
Thrown when a required property is not present
UndefinedPropertyException(String) - Constructor for exception com.linkedin.venice.exceptions.UndefinedPropertyException
 
UNDER_REPLICATED - com.linkedin.venice.meta.StoreStatus
 
UNDER_REPLICATED_PARTITION_SENSOR - Static variable in class com.linkedin.venice.controller.stats.PartitionHealthStats
 
unhealthyHosts - Variable in class com.linkedin.venice.router.api.VeniceHostHealth
 
UNIONIZE_WITH_NULL - com.linkedin.venice.etl.ETLValueSchemaTransformation
 
universalSet() - Static method in class com.linkedin.venice.utils.ComplementSet
Returns a set that contains all possible elements and is represented as a complement of an empty set.
UNKNOWN - com.linkedin.alpini.jna.ThreadUtils.OsPlatform
 
UNKNOWN - com.linkedin.venice.authorization.Method
 
UNKNOWN - com.linkedin.venice.authorization.Permission
 
UNKNOWN - com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
 
UNKNOWN - com.linkedin.venice.helix.HelixState
 
UNKNOWN - com.linkedin.venice.pushmonitor.ExecutionStatus
Job status is unknown when checking, and it could be caused by network issue
UNKNOWN - com.linkedin.venice.pushmonitor.HybridStoreQuotaStatus
 
UNKNOWN - com.linkedin.venice.status.PushJobDetailsStatus
 
UNKNOWN - com.linkedin.venice.utils.VeniceResourceCloseResult
 
UNKNOWN_METRIC_EXCEPTION - com.linkedin.venice.stats.StatsErrorCode
There was an exception when retrieving a metric value.
UNKNOWN_SCHEMA_ID - Static variable in class com.linkedin.venice.schema.SchemaData
 
UNKNOWN_TYPE_TOPIC - com.linkedin.venice.pubsub.api.PubSubTopicType
 
UNLIMITED_STORAGE_QUOTA - Static variable in interface com.linkedin.venice.meta.Store
 
unlink() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList.Entry
Removes this element from its list.
unlink(DoublyLinkedList.Entry<E>) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
Called to remove children from the list.
unlock() - Method in class com.linkedin.venice.utils.locks.AutoCloseableLock
Concrete implementations should do whatever work is required to unlock their inner lock(s).
unlock() - Method in class com.linkedin.venice.utils.locks.AutoCloseableMultiLock
 
unlock() - Method in class com.linkedin.venice.utils.locks.AutoCloseableSingleLock
 
unlock() - Method in class com.linkedin.venice.utils.VeniceLock
Attempt to unlock.
unmarkReusedStream(Http2StreamChannel) - Static method in class com.linkedin.alpini.netty4.misc.Http2Utils
Unmark a stream channel to indicate that reuse is completed.
unmask(int) - Static method in class com.linkedin.alpini.base.hash.Crc32C
Return the crc whose masked representation is masked_crc.
UNPOOLED_ALLOCATOR - Static variable in class com.linkedin.alpini.base.safealloc.SafeAllocator
 
UNREADY - com.linkedin.venice.controllerapi.NodeReplicasReadinessState
Node is live but not all current version replicas are ready.
unregister() - Method in class com.linkedin.venice.d2.D2Server
 
unregister() - Method in interface com.linkedin.venice.servicediscovery.ServiceDiscoveryAnnouncer
Unregister the instance from the service discovery system.
unregister(String) - Method in interface com.linkedin.venice.utils.PathResourceRegistry
 
unregister(String) - Method in class com.linkedin.venice.utils.TrieBasedPathResourceRegistry
 
UNREGISTER_METRIC_FOR_DELETED_STORE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
A config that determines whether to unregister per store metrics when a store is deleted.
unregisterAllSensors() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
 
unRegisterHandler(Class<T>, StatusMessageHandler<T>) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
unRegisterHandler(Class<T>, StatusMessageHandler<T>) - Method in interface com.linkedin.venice.status.StatusMessageChannel
Remove a handler for a specific message type.
unregisterRepairTasksForStoreIngestionTask(StoreIngestionTask) - Method in class com.linkedin.davinci.kafka.consumer.RemoteIngestionRepairService
 
unregisterRouter(String) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
unregisterRouter(String) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Unregister the given router instance from the cluster.
unregisterSerializer(String) - Method in class com.linkedin.venice.helix.HelixAdapterSerializer
 
unregisterStats() - Method in class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
 
unregisterStats() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
 
unregisterStats() - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
unregisterStoreDataChangedListener(StoreDataChangedListener) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
unregisterStoreDataChangedListener(StoreDataChangedListener) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
unregisterStoreDataChangedListener(StoreDataChangedListener) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
 
unregisterStoreDataChangedListener(StoreDataChangedListener) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Unregister store data change listener.
unregisterTransportClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactoryTestUtils
 
UnresolvedUnionUtil - Class in com.linkedin.venice.serializer
This class makes use of UnresolvedUnionException, which is not present in all versions of Avro.
UnresolvedUnionUtil() - Constructor for class com.linkedin.venice.serializer.UnresolvedUnionUtil
 
UNSORTED_INPUT_DRAINER_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
 
unsortedStoreBufferServiceDelegate - Variable in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
 
UNSPECIFIED_REPLICATION_METADATA_VERSION - Static variable in class com.linkedin.venice.ConfigConstants
Start of controller config default value
unsubscribe() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
unsubscribe(ComplementSet<Integer>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
unsubscribe(ComplementSet<Integer>) - Method in class com.linkedin.davinci.StoreBackend
 
unsubscribe(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
 
unsubscribe(String) - Method in class com.linkedin.venice.helix.SubscriptionBasedStoreRepository
 
unsubscribe(String) - Method in interface com.linkedin.venice.meta.SubscriptionBasedReadOnlyStoreRepository
 
unsubscribe(String, T) - Method in class com.linkedin.venice.listener.ListenerManager
 
unsubscribe(Set<Integer>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
unsubscribe(Set<Integer>) - Method in interface com.linkedin.davinci.client.DaVinciClient
Stop ingesting a partition locally, and drop its associated local states/data.
unsubscribe(Set<Integer>) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
unsubscribe(Set<Integer>) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Stop ingesting messages from a set of partitions for a specific store.
unsubscribe(Set<Integer>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
unSubscribe(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
 
unSubscribe(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
Unsubscribes the consumer from a specified topic-partition.
unSubscribe(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
 
unSubscribe(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
unSubscribe(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
Stop specific subscription associated with the given version topic.
unSubscribe(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
UNSUBSCRIBE - com.linkedin.davinci.kafka.consumer.ConsumerActionType
 
unsubscribeAll() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
 
unsubscribeAll() - Method in interface com.linkedin.davinci.client.DaVinciClient
Stop ingesting all subscribed partition locally, and drop their associated local states/data.
unsubscribeAll() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
 
unsubscribeAll() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
Stop ingesting messages from all partitions.
unsubscribeAll() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
unsubscribeAll(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
 
unsubscribeAll(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
Stop all subscription associated with the given version topic.
unsubscribeAll(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
 
unsubscribeAll(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.TopicWiseKafkaConsumerService
Detach the messages processing belonging to the topics of the passed {@param ingestionTask}
unsubscribeConsumerFor(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
 
unsubscribeDerivedSchemaCreationChanges(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
unsubscribeKeySchemaCreationChange(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
unSubscribePartition(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
unSubscribePartition(PubSubTopicPartition, boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Adds an asynchronous partition unsubscription request for the task.
unsubscribePartitionsStatusChange(OfflinePushStatus, PartitionStatusListener) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
unsubscribePartitionsStatusChange(OfflinePushStatus, PartitionStatusListener) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Unsubscribe the data change of partition status.
unsubscribePartitionsStatusChange(String, int, PartitionStatusListener) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
unsubscribePartitionsStatusChange(String, int, PartitionStatusListener) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Unsubscribe the data change of partition status.
unsubscribePushStatusCreationChange(IZkChildListener) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
unsubscribePushStatusCreationChange(IZkChildListener) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Unsubscribe a child listener
unsubscribeReplicationMetadataSchemaCreationChanges(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
unSubscribeRouterCountChangedEvent(RoutersClusterManager.RouterCountChangedListener) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
unSubscribeRouterCountChangedEvent(RoutersClusterManager.RouterCountChangedListener) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Stop listening on the router count.
unSubscribeRoutingDataChange(String, RoutingDataRepository.RoutingDataChangedListener) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
 
unSubscribeRoutingDataChange(String, RoutingDataRepository.RoutingDataChangedListener) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
Remove the listener for given kafka topic.
unsubscribeStoreConfigAddedOrDeletedListener(IZkChildListener) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
unsubscribeStoreConfigDataChangedListener(String, IZkDataListener) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
unsubscribeTopic(String) - Method in class com.linkedin.venice.pushmonitor.PushStatusCollector
 
unsubscribeValueSchemaCreationChange(String, IZkChildListener) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
 
UnsupportedMessageTypeException - Exception in com.linkedin.venice.exceptions.validation
This is thrown when some code encounters a message type it does not know about.
UnsupportedMessageTypeException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.UnsupportedMessageTypeException
 
UNUSED_SCHEMA_DELETION_ENABLED - com.linkedin.venice.Arg
 
UNUSED_SCHEMA_DELETION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
unusedSchemaDeletionEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether unused schema deletion is enabled or not.
unusedSchemaDeletionEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Store level config to indicate whether unused schema deletion is enabled or not.
UnusedValueSchemaCleanupService - Class in com.linkedin.venice.controller
This service runs in the parent controller to delete historical unused value schemas.
unvoid() - Method in class io.netty.bootstrap.PendingConnectFuturePromise
 
unvoid() - Method in class io.netty.bootstrap.PendingConnectPromise
 
unwrap(Class<T>) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
unwrap(Class<T>) - Method in interface com.linkedin.alpini.base.registry.ShutdownableExecutorService
Returns an object that implements the given interface to allow access to non-standard methods, or standard methods not exposed by the proxy.
unwrap(Class<T>) - Method in interface com.linkedin.alpini.router.api.RouterTimeoutProcessor
 
unwrap(Class<T>) - Method in class com.linkedin.alpini.router.impl.netty4.TimerTimeoutProcessor
 
unwrap(Class<W>) - Method in interface com.linkedin.alpini.base.pool.AsyncPool.LifeCycle
 
unwrap(Class<W>) - Method in class com.linkedin.alpini.base.pool.impl.LifeCycleFilter
 
unwrap(Throwable, Class<? extends E>) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Unwrap the cause of the given Throwable if the cause is assignable to the provided class; otherwise return null.
unwrapCompletion(Throwable) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Unwrap the cause of the given Throwable if the cause is assignable to the provided class; otherwise return null.
unwrapCompletion(Throwable) - Static method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
 
unwrapOptionalUnion(Schema) - Static method in class com.linkedin.davinci.schema.SchemaUtils
This function returns the type of the field if and only if it has a single non-null type.
upcomingAggregates - Variable in class com.linkedin.venice.kafka.protocol.StartOfSegment
An array of names of aggregate computation strategies for which there will be a value percolated in the corresponding EndOfSegment ControlMessage.
update(byte[]) - Method in class com.linkedin.alpini.base.hash.Crc32
 
update(byte[]) - Method in class com.linkedin.alpini.base.hash.Crc32C
 
update(byte[]) - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
Update the checksum buffer to include input
update(byte[], int, int) - Method in class com.linkedin.alpini.base.hash.Crc32
 
update(byte[], int, int) - Method in class com.linkedin.alpini.base.hash.Crc32C
 
update(byte[], int, int) - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
Update the checksum buffer to include input with startIndex and length.
update(int) - Method in class com.linkedin.alpini.base.hash.Crc32
 
update(int) - Method in class com.linkedin.alpini.base.hash.Crc32C
 
update(int) - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
Update the underlying buffer using the integer
update(short) - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
Update the underlying buffer using the short
update(ValueAndRmd<ByteBuffer>, Lazy<GenericRecord>, Schema, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeByteBuffer
 
update(ValueAndRmd<GenericRecord>, Lazy<GenericRecord>, Schema, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeGenericRecord
 
update(ValueAndRmd<T>, Lazy<GenericRecord>, Schema, long, int, long, int) - Method in interface com.linkedin.davinci.replication.merge.Merge
 
update(ClientConfig) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory.ClientConfigUpdater
 
update(Store) - Method in interface com.linkedin.venice.controller.VeniceHelixAdmin.StoreMetadataOperation
define the operation that update a store.
update(Lazy<ByteBuffer>, RmdWithValueSchemaId, ByteBuffer, int, int, long, long, int, int) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolver
 
update(K, U, int, int, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
 
update(K, U, int, int, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.VeniceWriter
 
update(K, U, int, int, PubSubProducerCallback, long) - Method in class com.linkedin.venice.writer.VeniceWriter
 
update(K, V, Version, AsyncCacheLoader<K, V>) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
 
update(ZkBaseDataAccessor<T>, String, T) - Static method in class com.linkedin.venice.utils.HelixUtils
 
update(ZkBaseDataAccessor<T>, String, T, int) - Static method in class com.linkedin.venice.utils.HelixUtils
 
Update - Class in com.linkedin.venice.kafka.protocol
Partial update operation, which merges the update value with the existing value.
Update() - Constructor for class com.linkedin.venice.kafka.protocol.Update
Default constructor.
Update(Integer, Integer, ByteBuffer) - Constructor for class com.linkedin.venice.kafka.protocol.Update
All-args constructor.
UPDATE - com.linkedin.venice.kafka.protocol.enums.MessageType
 
UPDATE_ACL - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_ADMIN_TOPIC_METADATA - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_CLUSTER_CONFIG - com.linkedin.venice.Command
 
UPDATE_CLUSTER_CONFIG - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_IGNORED_DCR - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
UPDATE_KAFKA_TOPIC_LOG_COMPACTION - com.linkedin.venice.Command
 
UPDATE_KAFKA_TOPIC_LOG_COMPACTION - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_KAFKA_TOPIC_MIN_IN_SYNC_REPLICA - com.linkedin.venice.Command
 
UPDATE_KAFKA_TOPIC_MIN_IN_SYNC_REPLICA - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_KAFKA_TOPIC_RETENTION - com.linkedin.venice.Command
 
UPDATE_KAFKA_TOPIC_RETENTION - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_KEY_HEADER_BYTE - Static variable in class com.linkedin.venice.kafka.protocol.enums.MessageType.Constants
 
UPDATE_METADATA - com.linkedin.venice.ingestion.protocol.enums.IngestionAction
 
UPDATE_SCHEMA_STRING_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
UPDATE_STORAGE_PERSONA - com.linkedin.venice.Command
 
UPDATE_STORAGE_PERSONA - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
UPDATE_STORAGE_PERSONA - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_STORE - com.linkedin.venice.Command
 
UPDATE_STORE - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
UPDATE_STORE - com.linkedin.venice.controllerapi.ControllerRoute
 
UPDATE_STORE_ACL - com.linkedin.venice.Command
 
updateAclForStore(Admin) - Method in class com.linkedin.venice.controller.server.CreateStore
 
updateAclForStore(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateAclForStore(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
Provision a new set of ACL for a venice store and its associated kafka topic.
updateAclForStore(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
updateAclForStore(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
updateAdminTopicMetadata(long, Optional<String>, Optional<Long>, Optional<Long>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateAdminTopicMetadata(Admin) - Method in class com.linkedin.venice.controller.server.AdminTopicMetadataRoutes
 
updateAdminTopicMetadata(String, long, long, long) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
Update cluster-level execution id, offset, and upstream offset in a child colo.
updateAdminTopicMetadata(String, long, Optional<String>, Optional<Long>, Optional<Long>) - Method in interface com.linkedin.venice.controller.Admin
 
updateAdminTopicMetadata(String, long, Optional<String>, Optional<Long>, Optional<Long>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update cluster-level execution id, offset and upstream offset.
updateAdminTopicMetadata(String, long, Optional<String>, Optional<Long>, Optional<Long>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
UpdateBuilder - Interface in com.linkedin.venice.writer.update
This class applies the builder pattern to build a partial update record.
UpdateBuilderImpl - Class in com.linkedin.venice.writer.update
 
UpdateBuilderImpl(Schema) - Constructor for class com.linkedin.venice.writer.update.UpdateBuilderImpl
 
updateCacheTimestamp(long) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
 
updateChecksum(byte[], int, int) - Method in class com.linkedin.venice.kafka.validation.checksum.Adler32CheckSum
 
updateChecksum(byte[], int, int) - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
 
updateChecksum(byte[], int, int) - Method in class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
 
updateChecksum(byte[], int, int) - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
 
updateChildren(List<String>, List<DataUpdater<ZNRecord>>, int) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
updateChildren(ZkBaseDataAccessor<T>, List<String>, List<T>) - Static method in class com.linkedin.venice.utils.HelixUtils
 
updateChildren(ZkBaseDataAccessor<T>, List<String>, List<T>, int) - Static method in class com.linkedin.venice.utils.HelixUtils
 
updateClusterConfig(Admin) - Method in class com.linkedin.venice.controller.server.ClusterRoutes
 
updateClusterConfig(UpdateClusterConfigQueryParams) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateClusterConfig(String, UpdateClusterConfigQueryParams) - Method in interface com.linkedin.venice.controller.Admin
 
updateClusterConfig(String, UpdateClusterConfigQueryParams) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Update the LiveClusterConfig at runtime for a specified cluster.
updateClusterConfig(String, UpdateClusterConfigQueryParams) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
UpdateClusterConfigQueryParams - Class in com.linkedin.venice.controllerapi
 
UpdateClusterConfigQueryParams() - Constructor for class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
UpdateClusterConfigQueryParams(Map<String, String>) - Constructor for class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
 
updateClusterConfigs(String, Map<String, String>) - Method in interface com.linkedin.venice.controller.HelixAdminClient
Update some Helix cluster properties for the given cluster.
updateClusterConfigs(String, Map<String, String>) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
 
updateClusterDiscovery(String, String, String, String) - Method in interface com.linkedin.venice.controller.Admin
Update the cluster discovery of a given store by writing to the StoreConfig ZNode.
updateClusterDiscovery(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
updateClusterDiscovery(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
updateCommandStatusForFabric(String, AdminCommandExecutionStatus) - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
 
updateConfig(StoreConfig, boolean) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
updateConfigs(LiveClusterConfig) - Method in class com.linkedin.venice.helix.HelixReadWriteLiveClusterConfigRepository
 
updateConfigs(LiveClusterConfig) - Method in interface com.linkedin.venice.meta.ReadWriteLiveClusterConfigRepository
Set live cluster configs
updateCurrentVersion(int) - Method in class com.linkedin.venice.fastclient.stats.ClusterStats
 
updateCurrentVersion(int) - Method in class com.linkedin.venice.router.stats.RouterCurrentVersionStats
 
UPDATED_CONFIGS_LIST - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
updateDataAge() - Method in class com.linkedin.venice.meta.RegionPushDetails
 
updatedConfigsList - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
The list that contains all updated configs by the UpdateStore command.
updateEndAndCurrentOffsets(ConsumerRecords<byte[], byte[]>, Consumer<byte[], byte[]>) - Method in class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
Update the end and current offsets of consumed partitions based on consumer metrics and given consumed records.
updateExpectedRouterCount(int) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
 
updateExpectedRouterCount(int) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
Update the expected number of routers in the cluster.
updateHeartbeatTime() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
 
updateHelixGroupInfo(Map<String, Integer>) - Method in class com.linkedin.venice.fastclient.meta.AbstractClientRoutingStrategy
 
updateHelixGroupInfo(Map<String, Integer>) - Method in class com.linkedin.venice.fastclient.meta.HelixScatterGatherRoutingStrategy
 
updateHybridQuotaReplicaStatus(String, int, HybridStoreQuotaStatus) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
 
updateKafkaTopicLogCompaction(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
 
updateKafkaTopicLogCompaction(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateKafkaTopicMinInSyncReplica(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
 
updateKafkaTopicMinInSyncReplica(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateKafkaTopicRetention(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
 
updateKafkaTopicRetention(String, long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateLastGeneratedExecutionId(String, Long) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
updateLastGeneratedExecutionId(String, Long) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
Update the last id which is generated by execution tracker in the given cluster.
updateLastGeneratedExecutionId(String, Long) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
 
updateLastSucceededExecutionId(String, Long) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
updateLastSucceededExecutionId(String, Long) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
Update the id of the last succeed operation in the given cluster.
updateLastSucceededExecutionId(String, Long) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
 
updateLastSucceededExecutionIdMap(String, String, Long) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
 
updateLastSucceededExecutionIdMap(String, String, Long) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
Update the execution id map that contains the last succeeded operation in the given cluster for each store.
updateLastSucceededExecutionIdMap(String, String, Long) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
 
updateLatestIgnoredUpstreamRTOffset(String, long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
updateLatestInMemoryLeaderConsumedRTOffset(PartitionConsumptionState, String, long) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
updateLatestInMemoryLeaderConsumedRTOffset(PartitionConsumptionState, String, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
updateLatestInMemoryProcessedOffset(PartitionConsumptionState, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, LeaderProducedRecordContext, String, boolean) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
 
updateLatestInMemoryProcessedOffset(PartitionConsumptionState, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, LeaderProducedRecordContext, String, boolean) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
updateLatestInMemoryProcessedOffset(PartitionConsumptionState, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, LeaderProducedRecordContext, String, boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Maintain the latest processed offsets by drainers in memory; in most of the time, these offsets are ahead of the checkpoint offsets inside OffsetRecord.
updateLatestProcessedLocalVersionTopicOffset(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
updateLatestProcessedUpstreamRTOffset(String, long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
updateLatestProcessedUpstreamVersionTopicOffset(long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
updateLatestRTOffsetTriedToProduceToVTMap(String, long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
updateLeaderConsumedUpstreamRTOffset(String, long) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
 
updateLeaderTopicOnFollower(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
updateLeaderTopicOnFollower(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
updateMetadata(IngestionStorageMetadata) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
 
updateMetadata(String, Map<String, Long>) - Method in class com.linkedin.venice.admin.InMemoryAdminTopicMetadataAccessor
 
updateMetadata(String, Map<String, Long>) - Method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
Update all relevant metadata for a given cluster in a single transaction.
updateMetadata(String, Map<String, Long>) - Method in class com.linkedin.venice.controller.ZkAdminTopicMetadataAccessor
 
updateMetricMap(Map<CharSequence, Double>) - Method in class com.linkedin.davinci.stats.IsolatedIngestionProcessStats
 
updateOfflinePushStatus(OfflinePushStatus) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
updateOfflinePushStatus(OfflinePushStatus) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Update status of the given offline push to persistent storage.
updateOffsetMetadataAndSync(String, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
updateOffsetMetadataInOffsetRecord(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
updateOffsetMetadataInOffsetRecord(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Sync the metadata about offset in OffsetRecord.
updateOffsetRecord(OffsetRecord) - Method in class com.linkedin.davinci.validation.PartitionTracker
 
updateOffsetRecordForPartition(int, OffsetRecord) - Method in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
For a given partition, find all the producers that has written to this partition and update the offsetRecord using segment information.
updateOffsetsFromConsumerRecord(PartitionConsumptionState, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, LeaderProducedRecordContext, LeaderFollowerStoreIngestionTask.UpdateVersionTopicOffset, LeaderFollowerStoreIngestionTask.UpdateUpstreamTopicOffset, LeaderFollowerStoreIngestionTask.GetLastKnownUpstreamTopicOffset, Supplier<String>, boolean) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
A helper function to the latest in-memory offsets processed by drainers in PartitionConsumptionState, after processing the given PubSubMessage.
updatePartitionOffsetRecords(String, int, List<ByteBuffer>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
This method updates all sub-partitions' latest offset records fetched from isolated ingestion process in main process, so main process's in-memory storage metadata service could be aware of the latest updates and will not re-start the ingestion from scratch.
updatePersona(StoragePersona) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
 
updatePersona(String, UpdateStoragePersonaQueryParams) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
Updates a persona with the given parameters.
updateProperty(PropertyKey, DataUpdater<ZNRecord>, T) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
updateProperty(PropertyKey, T) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
 
updatePushStatus(OfflinePushStatus, ExecutionStatus, Optional<String>) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
Direct calls to updatePushStatus should be made carefully.
updateRecord(Schema, GenericRecord, GenericRecord) - Method in class com.linkedin.davinci.schema.writecompute.WriteComputeProcessor
Apply write-compute operations on the given record.
updateRecordWithRmd(Schema, ValueAndRmd<GenericRecord>, GenericRecord, long, int) - Method in class com.linkedin.davinci.schema.writecompute.WriteComputeHandlerV2
Handle partial update request on a value record that has associated replication metadata.
updateRecordWithRmd(Schema, ValueAndRmd<GenericRecord>, GenericRecord, long, int) - Method in class com.linkedin.davinci.schema.writecompute.WriteComputeProcessor
 
updateReplicaStatus(HelixPartitionState, String, String, String) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
 
updateReplicaStatus(String, int, ExecutionStatus) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
 
updateReplicaStatus(String, int, String, ExecutionStatus, long, String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
updateReplicaStatus(String, int, String, ExecutionStatus, long, String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Update one particular replica status and progress by given topic, partition and instanceId to the persistent storage.
updateReplicaStatus(String, int, String, ExecutionStatus, String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
updateReplicaStatus(String, int, String, ExecutionStatus, String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
Update one particular replica status only by given topic, partition and instanceId to the persistent storage.
updateReplicaStatus(String, ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
updateReplicaStatus(String, ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.ReadOnlyPartitionStatus
 
updateReplicaStatus(String, ExecutionStatus, boolean) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
updateReplicaStatus(String, ExecutionStatus, boolean) - Method in class com.linkedin.venice.pushmonitor.ReadOnlyPartitionStatus
 
updateReplicaStatus(String, ExecutionStatus, String, long) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
 
updateReplicaStatus(String, ExecutionStatus, String, long) - Method in class com.linkedin.venice.pushmonitor.ReadOnlyPartitionStatus
 
updateResourceAssignment(ResourceAssignment) - Method in class com.linkedin.venice.helix.ResourceAssignment
Calculate resource assignment changes between the current one and the given one and also swap the current assignment to the given one in the end
UpdateResultStatus - Enum in com.linkedin.davinci.schema.merge
This enum represents status of something (a record or a field) after being updated.
updateRmdPayload(KafkaInputMapperValue, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
 
updateRmdPayload(ChunkAssembler.ValueBytesAndSchemaId, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
 
updateRmdPayload(INPUT_VALUE, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
updateRoutersClusterConfig(String, Optional<Boolean>, Optional<Boolean>, Optional<Boolean>, Optional<Integer>) - Method in interface com.linkedin.venice.controller.Admin
Update the cluster level for all routers.
updateRoutersClusterConfig(String, Optional<Boolean>, Optional<Boolean>, Optional<Boolean>, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
updateRoutersClusterConfig(String, Optional<Boolean>, Optional<Boolean>, Optional<Boolean>, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
updateSchemaConverter - Static variable in class com.linkedin.venice.controller.util.ParentControllerConfigUpdateUtils
 
updateSchemaId - Variable in class com.linkedin.venice.kafka.protocol.Update
The derived schema ID that will be used to deserialize updateValue.
updateState(String) - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
This runs after the state transition occurred.
updateStatsEmission(NavigableMap<String, StoreIngestionTask>, String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
This function will go through all known ingestion task in this server node, find the task that matches the storeName and has the largest version number; if the task doesn't enable metric emission, enable it and update store ingestion stats.
updateStatsEmission(NavigableMap<String, StoreIngestionTask>, String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
Find the task that matches both the storeName and maximumVersion number, enable metrics emission for this task and update ingestion stats with this task; disable metric emission for all the task that doesn't max version.
updateStatsVersionInfo(String, List<Version>, int) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
 
updateStatus(ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
updateStatus(ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
updateStatus(ExecutionStatus, String) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
 
updateStatus(ExecutionStatus, Optional<String>) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
 
updateStoragePersona(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
 
updateStoragePersona(String, UpdateStoragePersonaQueryParams) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateStoragePersona(String, String, UpdateStoragePersonaQueryParams) - Method in interface com.linkedin.venice.controller.Admin
 
updateStoragePersona(String, String, UpdateStoragePersonaQueryParams) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
updateStoragePersona(String, String, UpdateStoragePersonaQueryParams) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Updates a persona with the given parameters by sending a UPDATE_STORAGE_PERSONA admin message.
UpdateStoragePersona - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
UpdateStoragePersona() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
Default constructor.
UpdateStoragePersona(CharSequence, CharSequence, Long, List<CharSequence>, List<CharSequence>) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
All-args constructor.
UpdateStoragePersonaQueryParams - Class in com.linkedin.venice.controllerapi
 
UpdateStoragePersonaQueryParams() - Constructor for class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
UpdateStoragePersonaQueryParams(Map<String, String>) - Constructor for class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
 
updateStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
 
updateStore(Store) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
 
updateStore(Store) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepositoryAdapter
 
updateStore(Store) - Method in interface com.linkedin.venice.meta.ReadWriteStoreRepository
Update store in repository.
updateStore(String, ControllerClient, UpdateStoreQueryParams) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
updateStore(String, UpdateStoreQueryParams) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
updateStore(String, String, UpdateStoreQueryParams) - Method in interface com.linkedin.venice.controller.Admin
 
updateStore(String, String, UpdateStoreQueryParams) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
TODO: some logics are in parent controller VeniceParentHelixAdmin #updateStore and some are in the child controller here.
updateStore(String, String, UpdateStoreQueryParams) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Update a target store properties by first applying the provided deltas and then sending UPDATE_STORE admin message.
UpdateStore - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
UpdateStore() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Default constructor.
UpdateStore(CharSequence, CharSequence, CharSequence, Integer, Integer, Boolean, Boolean, Long, Long, HybridStoreConfigRecord, Boolean, Integer, Boolean, Boolean, Boolean, Boolean, Integer, Integer, Boolean, Boolean, Boolean, Integer, Boolean, Integer, Boolean, Integer, Boolean, Boolean, Boolean, Boolean, ETLStoreConfigRecord, PartitionerConfigRecord, Boolean, CharSequence, Integer, Integer, Long, Integer, Boolean, CharSequence, Boolean, Boolean, Boolean, Boolean, List<CharSequence>, Boolean, CharSequence, CharSequence, Map<String, StoreViewConfigRecord>, Integer, Boolean, Long, Long, Boolean, Boolean) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
All-args constructor.
UpdateStoreQueryParams - Class in com.linkedin.venice.controllerapi
 
UpdateStoreQueryParams() - Constructor for class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
UpdateStoreQueryParams(StoreInfo, boolean) - Constructor for class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
This method must be updated everytime a new store property is introduced
UpdateStoreQueryParams(Map<String, String>) - Constructor for class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
 
updateStoreToHybrid(String, ControllerClient, Optional<Boolean>, Optional<Boolean>, Optional<Boolean>) - Static method in class com.linkedin.venice.utils.TestUtils
 
updateStoreVersionStateCache(StoreVersionState) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
Used in ingestion isolation mode update the storage engine's cache in sync with the updates to the state in MainIngestionStorageMetadataService
updateSystemStoreAclForStore(String, String, AclBinding) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Set the AceEntries in provided AclBinding object to be the current set of ACL's for the resource.
updateTopicCompactionPolicy(PubSubTopic, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
updateTopicCompactionPolicy(PubSubTopic, boolean, long, Optional<Long>) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Update topic compaction policy.
updateTopicMinInSyncReplica(PubSubTopic, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
updateTopicRetention(PubSubTopic, long) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Update retention for the given topic.
updateTopicRetention(PubSubTopic, long, PubSubTopicConfiguration) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
Update retention for the given topic given a Properties.
updateTotalStats(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
Some versioned stats might always increasing; in this case, the value in the total stats should be updated with the aggregated values across the new version list.
updateTotalStats(String) - Method in class com.linkedin.davinci.stats.AggVersionedDIVStats
 
updateValue - Variable in class com.linkedin.venice.kafka.protocol.Update
New value(s) for parts of the record that need to be updated.
updateValuePayload(KafkaInputMapperValue, byte[]) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
 
updateValuePayload(ChunkAssembler.ValueBytesAndSchemaId, byte[]) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
 
updateValuePayload(INPUT_VALUE, byte[]) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
updateValueRecord(Schema, GenericRecord, GenericRecord) - Method in interface com.linkedin.venice.schema.writecompute.WriteComputeHandler
Execute write-compute operation on a value record.
updateValueRecord(Schema, GenericRecord, GenericRecord) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeHandlerV1
 
updateVersionStatus(int, VersionStatus) - Method in class com.linkedin.venice.meta.AbstractStore
 
updateVersionStatus(int, VersionStatus) - Method in class com.linkedin.venice.meta.ReadOnlyStore
 
updateVersionStatus(int, VersionStatus) - Method in interface com.linkedin.venice.meta.Store
 
upgrade(TransportSecurityLayer, NamedEndpoint, Object, Timeout, FutureCallback<TransportSecurityLayer>) - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategy
 
UPGRADED - com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
 
upgradeFrom(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpClientCodec
Upgrades to another protocol from HTTP.
upgradeFrom(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
Upgrades to another protocol from HTTP.
UPLOAD_PUSH_JOB_STATUS - com.linkedin.venice.controllerapi.ControllerRoute
 
uploadPushInfo(Admin) - Method in class com.linkedin.venice.controller.server.CreateVersion
Deprecated.
uploadPushJobStatus(Admin) - Method in class com.linkedin.venice.controller.server.JobRoutes
 
UPSTREAM_OFFSET - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
upstreamKafkaClusterId - Variable in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Kafka bootstrap server URL of the cluster where RT/GF/remote VT topic exists, represented by an integer to reduce the overhead.
upstreamOffset - Variable in class com.linkedin.venice.kafka.protocol.LeaderMetadata
Where this message is located in RT/GF/remote VT topic.
upstreamOffsetMap - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
A map of upstream Kafka bootstrap server url -> the last Kafka offset consumed from upstream topic.
upstreamVersionTopicOffset - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
The last upstream version topic offset persisted to disk; if the batch native-replication source is the same as local region, this value will always be -1
URL - com.linkedin.venice.Arg
 
URLCodec - Enum in com.linkedin.alpini.base.misc
Copies of the implementation of URLEncoder.encode(String, String) and URLDecoder.decode(String, String) except with the following changes: Accept a Charset argument for the character set instead of a string which would cause Charset.forName(String) to be called. Internally use StringBuilder instead of StringBuffer. These methods no longer throw a checked exception because it no longer calls Charset.forName(String). These methods are annotated with Nonnull annotations.
US_PER_MS - Static variable in interface com.linkedin.venice.utils.Time
 
US_PER_SECOND - Static variable in interface com.linkedin.venice.utils.Time
 
USE_DA_VINCI_SPECIFIC_EXECUTION_STATUS_FOR_ERROR - Static variable in class com.linkedin.venice.ConfigKeys
when enabled, Da Vinci Clients returns specific status codes to indicate the type of ingestion failure rather than a generic com.linkedin.venice.pushmonitor.ExecutionStatus.ERROR
USE_FAST_KAFKA_OPERATION_TIMEOUT - Static variable in class com.linkedin.venice.views.ViewUtils
 
USE_MAPPER_TO_BUILD_DICTIONARY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config to enable/disable using mapper to do the below which are currently done in VPJ driver
1.
USE_PER_RECORD_LOGICAL_TIMESTAMP - com.linkedin.davinci.replication.BatchConflictResolutionPolicy
Per-record replication metadata is provided by the push job and stored for each key, enabling full conflict resolution granularity on a per field basis, just like when merging concurrent update operations.
USE_PUSH_STATUS_STORE_FOR_INCREMENTAL_PUSH - Static variable in class com.linkedin.venice.ConfigKeys
A config to control which status store to use for fetching incremental push job status from the controller.
USE_START_OF_PUSH_TIMESTAMP - com.linkedin.davinci.replication.BatchConflictResolutionPolicy
Start-Of-Push Control message's timestamp should be treated as the last update replication timestamp for all batch records, and hybrid writes wins only when their own logicalTimestamp are higher.
useCustomH2Codec() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
useCustomMultiplexHandler(boolean) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
Deprecated.
useCustomMultiplexHandler(boolean) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
useCustomMultiplexHandler(boolean) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
useDaVinciSpecificExecutionStatusForError() - Method in class com.linkedin.davinci.config.VeniceServerConfig
 
useDaVinciSpecificExecutionStatusForError() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
usedDirectMemory() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocatorMetric
 
usedHeapMemory() - Method in class com.linkedin.alpini.base.safealloc.SafeAllocatorMetric
 
useForNull(String) - Method in class com.linkedin.alpini.base.misc.Joiner
 
useGrpc() - Method in class com.linkedin.venice.fastclient.ClientConfig
 
useMapperToBuildDict - Variable in class com.linkedin.venice.hadoop.PushJobSetting
useMapperToBuildDictOutputPath - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
useOpenSsl() - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
 
usePushStatusStoreForIncrementalPush() - Method in class com.linkedin.venice.controller.VeniceControllerConfig
 
USER_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
USER_WITH_DEFAULT_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
USER_WITH_FLOAT_ARRAY_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
 
UserCredentialsFactory - Class in com.linkedin.venice.hadoop.ssl
 
UserCredentialsFactory() - Constructor for class com.linkedin.venice.hadoop.ssl.UserCredentialsFactory
 
userEventChunkingAdapter - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.LogSslCipherSuiteHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.ssl.SecureClientHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.linkedin.venice.listener.RouterRequestHttpHandler
This function is used to support http keep-alive.
userEventTriggered(ChannelHandlerContext, Object) - Method in class com.linkedin.venice.router.RouterSslVerificationHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.http2.ActiveStreamsCountHandler
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
 
UserPartitionAwarePartitioner - Class in com.linkedin.venice.partitioner
UserPartitionAwarePartitioner takes a partitioner and amplification factor as input params.
UserPartitionAwarePartitioner(VenicePartitioner, int) - Constructor for class com.linkedin.venice.partitioner.UserPartitionAwarePartitioner
 
UserSystemStoreLifeCycleHelper - Class in com.linkedin.venice.controller
This class is responsible for automatically create and delete per user store system store resources when the corresponding user store is created or deleted.
UserSystemStoreLifeCycleHelper(VeniceParentHelixAdmin, Optional<AuthorizerService>, VeniceControllerMultiClusterConfig) - Constructor for class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
 
useSystemProperties() - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
Use system properties when creating and configuring default implementations.
useVersionLevelHybridConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Flag to see if hybridConfig at StoreVersion should be used.
useVersionLevelIncrementalPushEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
Flag to see if incrementalPushEnabled config at StoreVersion should be used.
UTF_8 - Static variable in class com.linkedin.venice.meta.SimpleStringSerializer
 
Utils - Class in com.linkedin.venice.utils
Helper functions
Utils() - Constructor for class com.linkedin.venice.utils.Utils
 
Utils.ConfigEntity<T> - Class in com.linkedin.venice.utils
This class encapsulates config entity information such as config name, default value, config document

V

V1Delete - Enum in com.linkedin.venice.controllerapi.routes
 
V1Get - Enum in com.linkedin.venice.controllerapi.routes
Controller API version 1 HTTP GET routes
V1Post - Enum in com.linkedin.venice.controllerapi.routes
 
V1Put - Enum in com.linkedin.venice.controllerapi.routes
 
V1Route - Interface in com.linkedin.venice.controllerapi.routes
 
vacuum() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Vacuums any already-terminated resources.
VALID_AVRO_NAME_PATTERN - Static variable in class com.linkedin.venice.compute.ComputeUtils
 
VALID_LAG - Static variable in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
validate() - Method in class com.linkedin.venice.hadoop.validation.NoOpValidator
 
validate() - Method in interface com.linkedin.venice.hadoop.validation.Validator
 
validate() - Method in class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
validate(Schema, Schema) - Static method in class com.linkedin.davinci.schema.writecompute.WriteComputeSchemaValidator
 
VALIDATE_SCHEMA_AND_BUILD_DICT_MAP_JOB_COMPLETED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
VALIDATE_SCHEMA_AND_BUILD_DICT_MAPPER_OUTPUT_DIRECTORY - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Location and key to store the output of ValidateSchemaAndBuildDictMapper and retrieve it back when USE_MAPPER_TO_BUILD_DICTIONARY is enabled
VALIDATE_SCHEMA_AND_BUILD_DICTIONARY_MAPPER_OUTPUT_FILE_EXTENSION - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
VALIDATE_SCHEMA_AND_BUILD_DICTIONARY_MAPPER_OUTPUT_FILE_PREFIX - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
VALIDATE_SCHEMA_AND_BUILD_DICTIONARY_MAPPER_OUTPUT_PARENT_DIR_DEFAULT - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
VALIDATE_VENICE_INTERNAL_SCHEMA_VERSION - Static variable in class com.linkedin.venice.ConfigKeys
Config to check whether the protocol versions used at runtime are valid in Venice backend; if not, fail fast.
validateAddUpdatedStore(StoragePersona, Optional<Store>) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
validateAndCopyKafkaSSLConfig(VeniceProperties, Properties) - Static method in class com.linkedin.venice.utils.KafkaSSLUtils
This function will extract SSL related config if Kafka SSL is enabled.
validateAndExecuteCommand(IngestionCommandType, IngestionTaskReport, Runnable) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerHandler
 
validateAndMaybeRetrySystemStoreAutoCreation(String, String, VeniceSystemStoreType) - Method in interface com.linkedin.venice.controller.Admin
 
validateAndMaybeRetrySystemStoreAutoCreation(String, String, VeniceSystemStoreType) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Check the creation results of a user store's system store.
validateAndMaybeRetrySystemStoreAutoCreation(String, String, VeniceSystemStoreType) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Unsupported operation in the parent controller.
validateAvroSchemaStr(String) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
It verifies that the schema's union field default value must be same type as the first field.
validateAvroSchemaStr(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
 
validateBatchIngestion() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
 
validateBatchIngestion() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
 
validateBatchIngestion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
 
validateBatchIngestion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
validateConfigs() - Method in class com.linkedin.venice.views.ChangeCaptureView
 
validateConfigs() - Method in class com.linkedin.venice.views.VeniceView
Validate that the configs set up for this view for this store are valid.
validateFieldSchemaType(String, Schema, Schema.Type) - Static method in class com.linkedin.davinci.schema.SchemaUtils
This method checks if the field contains expected type.
validateHeaders - Variable in class com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder
 
validateHeaders(boolean) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
validateHookConfig(String, String, String, String) - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
Invoked prior to updating a store's config with a given hook config.
validateInputAndGetInfo(String) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
1.
validateInputAndGetInfo(String) - Method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
 
validateInputAndGetInfo(String) - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
 
validateJob() - Method in class com.linkedin.venice.hadoop.jobs.DataWriterComputeJob
 
validateMessage(KafkaDataIntegrityValidator, PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, boolean, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
Message validation using DIV.
validateMessage(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, boolean, Lazy<Boolean>) - Method in class com.linkedin.davinci.validation.KafkaDataIntegrityValidator
Run a thorough DIV check on the message, including UNREGISTERED_PRODUCER, MISSING, CORRUPT and DUPLICATE.
validateMessage(PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>, boolean, Lazy<Boolean>) - Method in class com.linkedin.davinci.validation.PartitionTracker
Ensures the integrity of the data by maintaining state about all of the data produced by a specific upstream producer: 1.
validateNullableFieldAndGetErrorMsg(ReadComputeOperator, GenericRecord, Schema.Field, String) - Static method in class com.linkedin.venice.compute.ComputeUtils
 
validateParams(Request, List<String>, Admin) - Static method in class com.linkedin.venice.controller.server.AdminSparkServer
 
validatePersona(StoragePersona) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
validatePersona(String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
validatePersonaUpdate(String, UpdateStoragePersonaQueryParams) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
 
validatePushStatusTransition(ExecutionStatus) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
Judge whether current status could be transferred to the new status.
validateRemoteHybridSettings() - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
validateRemoteHybridSettings(PushJobSetting) - Method in class com.linkedin.venice.hadoop.VenicePushJob
 
validateRemoteReplayPolicy - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
validateSchemaAndBuildDictJobConf - Variable in class com.linkedin.venice.hadoop.VenicePushJob
 
ValidateSchemaAndBuildDictMapper - Class in com.linkedin.venice.hadoop
Mapper only MR to Validate Schema, Build compression dictionary if needed and persist some data (total file size and compression dictionary) in HDFS to be used by the VPJ Driver Note: processing all the files in this split are done sequentially and if it results in significant increase in the mapper time or resulting in timeouts, this needs to be revisited to be done via a thread pool.
ValidateSchemaAndBuildDictMapper() - Constructor for class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapper
 
ValidateSchemaAndBuildDictMapperOutput - Class in com.linkedin.venice.hadoop.output.avro
The data protocol between ValidateSchemaAndBuildDictMapper and VenicePushJob
ValidateSchemaAndBuildDictMapperOutput() - Constructor for class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
Default constructor.
ValidateSchemaAndBuildDictMapperOutput(Long, ByteBuffer) - Constructor for class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
All-args constructor.
ValidateSchemaAndBuildDictMapperOutputReader - Class in com.linkedin.venice.hadoop
This class reads the data(total input size in bytes and zstd dictionary) persisted in HDFS by ValidateSchemaAndBuildDictMapper based on the schema ValidateSchemaAndBuildDictMapperOutput
ValidateSchemaAndBuildDictMapperOutputReader(String, String) - Constructor for class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictMapperOutputReader
 
ValidateSchemaAndBuildDictOutputFormat - Class in com.linkedin.venice.hadoop
This class provides a way to: 1.
ValidateSchemaAndBuildDictOutputFormat() - Constructor for class com.linkedin.venice.hadoop.ValidateSchemaAndBuildDictOutputFormat
 
validateSchemaType(Schema, Schema.Type) - Method in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
 
validateSslProperties(VeniceProperties) - Static method in class com.linkedin.venice.hadoop.utils.VPJSSLUtils
 
validateSubsetValueSchema(Schema, String) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
 
validateTopLevelFieldDefaultsValueRecordSchema(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
 
Validator - Interface in com.linkedin.venice.hadoop.validation
Interface for targeted region push validation.
value - Variable in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
value - Variable in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
The serialized result can be de-serialized by the result schema passed in the compute request
value - Variable in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Raw bytes of the value
value - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
The raw value bytes
value - Variable in enum com.linkedin.venice.meta.OfflinePushStrategy
 
value - Variable in enum com.linkedin.venice.meta.PersistenceType
 
value - Variable in enum com.linkedin.venice.meta.ReadStrategy
 
value - Variable in enum com.linkedin.venice.meta.RoutingStrategy
 
value - Variable in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
Avro serialized value
value - Variable in class com.linkedin.venice.unit.kafka.InMemoryKafkaMessage
 
value - Variable in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter.SendMessageParameters
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XClusterName
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XErrorCauseClass
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XErrorCauseMessage
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XErrorClass
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XErrorInResponse
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XErrorMessage
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XMetrics
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XMultipartContentStatus
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XPartition
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XRequestId
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XResponseBoundary
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XReturnMetrics
 
value() - Method in annotation type com.linkedin.alpini.base.misc.HeaderNames.XServedBy
 
value() - Method in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation.Sample
 
value() - Method in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation.Sample
 
value() - Method in class com.linkedin.alpini.base.statistics.LongQuantileEstimation.Sample
 
value() - Method in annotation type com.linkedin.alpini.cli.CLIFooter
Footer text.
value() - Method in annotation type com.linkedin.alpini.cli.CLIHeader
Header text.
value() - Method in annotation type com.linkedin.alpini.router.api.NettyVersion
 
value() - Method in class com.linkedin.davinci.store.record.ByteBufferValueRecord
 
value() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeader
 
VALUE_COLUMN_NAME - Static variable in class com.linkedin.venice.hadoop.spark.SparkConstants
 
VALUE_FIELD_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
VALUE_LEVEL_TIMESTAMP - com.linkedin.venice.schema.rmd.RmdTimestampType
 
VALUE_SCHEMA - com.linkedin.venice.Arg
 
VALUE_SCHEMA - com.linkedin.venice.controllerapi.routes.V1Get
 
VALUE_SCHEMA - com.linkedin.venice.controllerapi.routes.V1Post
 
VALUE_SCHEMA - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
VALUE_SCHEMA_CREATION - com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
 
VALUE_SCHEMA_DIR - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
VALUE_SCHEMA_ID - com.linkedin.venice.Arg
 
VALUE_SCHEMA_ID_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
VALUE_SCHEMA_IDS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
VALUE_SCHEMA_STARTING_ID - Static variable in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
 
VALUE_SCHEMA_STARTING_ID - Static variable in class com.linkedin.venice.helix.HelixSchemaAccessor
 
VALUE_SCHEMAS - com.linkedin.venice.controllerapi.routes.V1Get
 
VALUE_SCHEMAS_WRITTEN_PER_STORE_VERSION - com.linkedin.venice.system.store.MetaStoreDataType
 
ValueAndDerivedSchemaData - Class in com.linkedin.venice
 
ValueAndDerivedSchemaData(String) - Constructor for class com.linkedin.venice.ValueAndDerivedSchemaData
 
ValueAndRmd<T> - Class in com.linkedin.davinci.schema.merge
This class holds a value of type {@param T} and its corresponding replication metadata.
ValueAndRmd(Lazy<T>, GenericRecord) - Constructor for class com.linkedin.davinci.schema.merge.ValueAndRmd
 
ValueBytes - Class in com.linkedin.venice.client.change.capture.protocol
Optional field which describes the previous state of a given row.
ValueBytes() - Constructor for class com.linkedin.venice.client.change.capture.protocol.ValueBytes
Default constructor.
ValueBytes(ByteBuffer, Integer) - Constructor for class com.linkedin.venice.client.change.capture.protocol.ValueBytes
All-args constructor.
valueCharSequenceIterator(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
valueCompressionStrategy - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
0 => NO_OP, 1 => GZIP
valueField - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
valueOf(int) - Static method in enum com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.davinci.replication.BatchConflictResolutionPolicy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.compression.CompressionStrategy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.controller.kafka.protocol.enums.SchemaType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.hadoop.input.kafka.ttl.TTLResolutionPolicy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionComponentType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.kafka.protocol.enums.ControlMessageType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.kafka.protocol.enums.MessageType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.kafka.validation.checksum.CheckSumType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.kafka.validation.SegmentStatus
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.meta.BufferReplayPolicy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.meta.DataReplicationPolicy
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.meta.IngestionMetadataUpdateType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.meta.IngestionMode
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.meta.Version.PushType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.system.store.MetaStoreDataType
Returns the enum constant of this type with the specified name.
valueOf(int) - Static method in enum com.linkedin.venice.writer.LeaderCompleteState
Returns the enum constant of this type with the specified name.
valueOf(ComputeOperation) - Static method in enum com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
Returns the enum constant of this type with the specified name.
valueOf(AdminOperation) - Static method in enum com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
Returns the enum constant of this type with the specified name.
valueOf(ControlMessage) - Static method in enum com.linkedin.venice.kafka.protocol.enums.ControlMessageType
Returns the enum constant of this type with the specified name.
valueOf(KafkaMessageEnvelope) - Static method in enum com.linkedin.venice.kafka.protocol.enums.MessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.concurrency.AsyncFuture.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.concurrency.ConcurrentAccumulator.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.DateUtils
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.HeaderNames
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.JDBCUtils
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.MetricNames
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.Preconditions
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.ProcessUtil
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.SimpleJsonMapper
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.Time
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.misc.URLCodec
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.monitoring.CallTrackerImpl.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.queuing.QOSPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.base.test.TestUtil
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.consts.QOS
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.io.IOUtils
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.jna.ThreadUtils.OsPlatform
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.netty4.handlers.VIPRequestHandler.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.netty4.misc.AsciiStringURLCodec
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.netty4.misc.HttpUtils
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.netty4.misc.NettyUtils.Mode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.netty4.misc.NettyUtils.ReadMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.alpini.router.api.Netty
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.client.StorageClass
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory.LeaderFollowerThreadPoolStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.ingestion.LagType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.ingestion.main.MainPartitionIngestionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.kafka.consumer.ConsumerActionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.kafka.consumer.KafkaConsumerService.ConsumerAssignmentStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.kafka.consumer.StoreIngestionTask.DelegateConsumerRecordResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.replication.BatchConflictResolutionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.schema.merge.UpdateResultStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.davinci.store.rocksdb.RocksDBBlockCacheImplementations
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.Arg
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.authorization.Method
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.authorization.Permission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.chunking.ChunkKeyValueTransformer.KeyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.client.store.deserialization.BatchDeserializerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.Command
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.common.StoreMetadataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.common.VeniceSystemStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.compression.CompressionStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controller.kafka.protocol.enums.SchemaType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controller.NodeRemovableResult.BlockingRemoveReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controllerapi.ControllerRoute
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controllerapi.NodeReplicasReadinessState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controllerapi.routes.V1Delete
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controllerapi.routes.V1Get
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controllerapi.routes.V1Post
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.controllerapi.routes.V1Put
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.etl.ETLValueSchemaTransformation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.exceptions.ErrorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.exceptions.ExceptionType
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.fastclient.meta.ClientRoutingStrategyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.fastclient.meta.StoreMetadataFetchMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.fastclient.utils.ClientTestUtils.FastClientHTTPVariant
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.hadoop.input.kafka.ttl.TTLResolutionPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.hadoop.jobs.ComputeJob.Status
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.helix.HelixPartitionState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.helix.HelixState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.helix.HelixViewPropertyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.hooks.StoreLifecycleEventOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.hooks.StoreVersionLifecycleEventOutcome
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.HttpMethod
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionComponentType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.kafka.protocol.enums.ControlMessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.kafka.protocol.enums.MessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.kafka.validation.checksum.CheckSumType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.kafka.validation.SegmentStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.BackupStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.BufferReplayPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.DataReplicationPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.IngestionMetadataUpdateType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.IngestionMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.InstanceStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.OfflinePushStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.PersistenceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.QueryAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.ReadStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.RoutingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.ServerAdminAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.StoreStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.VeniceUserStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.Version.PushType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.meta.VersionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.migration.MigrationPushStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.participant.protocol.enums.ParticipantMessageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.pubsub.api.PubSubTopicType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.pushmonitor.HybridStoreQuotaStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.pushmonitor.PushMonitorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.pushmonitor.SubPartitionStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.read.RequestType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.router.api.RouterResourceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategyEnum
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.router.api.VeniceMultiKeyRoutingStrategy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.router.api.VeniceRole
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.router.httpclient.StorageNodeClientType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.router.stats.StaleVersionReason
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.samza.SamzaExitMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaCompatibilityType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.schema.rmd.RmdTimestampType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.schema.writecompute.WriteComputeOperation
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl
Deprecated.
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.service.AbstractVeniceService.ServiceState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.stats.StatsErrorCode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.status.protocol.enums.PushJobStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.status.PushJobDetailsStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.system.store.MetaStoreDataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.utils.concurrent.BlockingQueueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.utils.TestWriteUtils.TestRecordType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.utils.TestWriteUtils.TestTargetedField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.utils.VeniceResourceCloseResult
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.linkedin.venice.writer.LeaderCompleteState
Returns the enum constant of this type with the specified name.
valueOfPath(String) - Static method in enum com.linkedin.venice.controllerapi.ControllerRoute
 
ValueRecord - Class in com.linkedin.davinci.store.record
This class provides the following functionalities: 1.
values() - Static method in enum com.linkedin.alpini.base.concurrency.AsyncFuture.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.concurrency.ConcurrentAccumulator.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.concurrency.Executors
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.CollectionUtil
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.DateUtils
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.HeaderNames
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.HeaderUtils
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.JDBCUtils
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.MetricNames
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.Preconditions
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.ProcessUtil
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.SimpleJsonMapper
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.Time
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.TimeFormat
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.misc.URLCodec
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.monitoring.CallTrackerImpl.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.queuing.QOSPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.base.test.TestUtil
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.consts.QOS
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.io.IOUtils
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.jna.ThreadUtils.OsPlatform
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.netty4.handlers.VIPRequestHandler.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.netty4.misc.AsciiStringURLCodec
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.netty4.misc.BasicHttpObjectDecoder.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.netty4.misc.HttpUtils
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.netty4.misc.NettyUtils.Mode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.netty4.misc.NettyUtils.ReadMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.alpini.router.api.Netty
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.client.StorageClass
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory.LeaderFollowerThreadPoolStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.ingestion.LagType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.ingestion.main.MainPartitionIngestionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.kafka.consumer.ConsumerActionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.kafka.consumer.KafkaConsumerService.ConsumerAssignmentStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.kafka.consumer.StoreIngestionTask.DelegateConsumerRecordResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.replication.BatchConflictResolutionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.schema.merge.UpdateResultStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.davinci.store.rocksdb.RocksDBBlockCacheImplementations
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.linkedin.davinci.utils.IndexedHashMap
Returns a Collection view of the values contained in this map.
values() - Static method in enum com.linkedin.venice.Arg
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.authorization.Method
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.authorization.Permission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.chunking.ChunkKeyValueTransformer.KeyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.client.store.deserialization.BatchDeserializerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.Command
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.common.StoreMetadataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.common.VeniceSystemStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.compression.CompressionStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controller.kafka.protocol.enums.SchemaType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controller.NodeRemovableResult.BlockingRemoveReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controllerapi.ControllerRoute
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controllerapi.NodeReplicasReadinessState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controllerapi.routes.V1Delete
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controllerapi.routes.V1Get
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controllerapi.routes.V1Post
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.controllerapi.routes.V1Put
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.etl.ETLValueSchemaTransformation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.exceptions.ErrorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.exceptions.ExceptionType
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.fastclient.meta.ClientRoutingStrategyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.fastclient.meta.StoreMetadataFetchMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.fastclient.utils.ClientTestUtils.FastClientHTTPVariant
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.hadoop.input.kafka.ttl.TTLResolutionPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.hadoop.jobs.ComputeJob.Status
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.helix.HelixPartitionState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.helix.HelixState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.helix.HelixViewPropertyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.hooks.StoreLifecycleEventOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.hooks.StoreVersionLifecycleEventOutcome
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.HttpMethod
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionComponentType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.kafka.protocol.enums.ControlMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.kafka.protocol.enums.MessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.kafka.validation.checksum.CheckSumType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.kafka.validation.SegmentStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.BackupStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.BufferReplayPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.DataReplicationPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.IngestionMetadataUpdateType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.IngestionMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.InstanceStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.OfflinePushStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.PersistenceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.QueryAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.ReadStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.RoutingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.ServerAdminAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.StoreStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.VeniceUserStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.Version.PushType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.meta.VersionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.migration.MigrationPushStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.participant.protocol.enums.ParticipantMessageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.pubsub.api.PubSubTopicType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.pushmonitor.ExecutionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.pushmonitor.HybridStoreQuotaStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.pushmonitor.PushMonitorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.pushmonitor.SubPartitionStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.read.RequestType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.FailureType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.router.api.RouterResourceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategyEnum
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.router.api.VeniceMultiKeyRoutingStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.router.api.VeniceRole
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.router.httpclient.StorageNodeClientType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.router.stats.StaleVersionReason
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.samza.SamzaExitMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaCompatibilityType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.schema.rmd.RmdTimestampType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.schema.vson.VsonTypes
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.schema.writecompute.WriteComputeOperation
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.serialization.avro.AvroProtocolDefinition
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl
Deprecated.
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.service.AbstractVeniceService.ServiceState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.stats.StatsErrorCode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.status.protocol.enums.PushJobStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.status.PushJobDetailsStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.system.store.MetaStoreDataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.utils.concurrent.BlockingQueueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class com.linkedin.venice.utils.SparseConcurrentList
 
values() - Static method in enum com.linkedin.venice.utils.TestWriteUtils.TestRecordType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.utils.TestWriteUtils.TestTargetedField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.utils.VeniceResourceCloseResult
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.linkedin.venice.writer.LeaderCompleteState
Returns an array containing the constants of this enum type, in the order they are declared.
VALUES - Static variable in enum com.linkedin.venice.common.VeniceSystemStoreType
 
valueSchema - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
valueSchema - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
valueSchema - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
valueSchema - Variable in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
Store value schema string.
ValueSchemaCreation - Class in com.linkedin.venice.controller.kafka.protocol.admin
 
ValueSchemaCreation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
Default constructor.
ValueSchemaCreation(CharSequence, CharSequence, SchemaMeta, Integer, Boolean) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
All-args constructor.
valueSchemaDir - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
valueSchemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
valueSchemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
valueSchemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
valueSchemaId - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
valueSchemaID - Variable in class com.linkedin.venice.schema.GeneratedSchemaEntry
 
valueSchemaMap - Variable in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
valueSchemaMap - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
A string to string map representing the mapping from schema id to value schema string.
valueSchemaMap - Variable in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
A string to string map representing the mapping from schema id to value schema string.
valueSchemas - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
Value schemas
valueSchemaString - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
valueStringIterator(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
 
valueType - Variable in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
The value type of the message
VENICE_AGGREGATE - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
Whether to leverage Venice aggregation.
VENICE_ALLOW_REDIRECT - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_API_VERSION - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_CHILD_CONTROLLER_D2_SERVICE - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
VENICE_CHILD_D2_ZK_HOSTS - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
D2 ZK hosts for Venice Child Cluster.
VENICE_CLIENT_COMPUTE - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_CLIENT_SSL_CONFIG_FILE - com.linkedin.venice.Arg
 
VENICE_COMPRESSION_STRATEGY - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_COMPUTATION_ERROR_MAP_FIELD_NAME - Static variable in class com.linkedin.venice.VeniceConstants
The following field is used to construct result schema for compute API.
VENICE_COMPUTE_VALUE_SCHEMA_ID - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_CONFIG_DIR - Static variable in class com.linkedin.davinci.config.VeniceConfigLoader
 
VENICE_CONTROLLER_DISCOVERY_URL - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
VENICE_DEFAULT_LOGICAL_TS - Static variable in class com.linkedin.venice.writer.VeniceWriter
This sentinel value indicates that the venice samza apps do not support the logical timestamp.
VENICE_DEFAULT_TIMESTAMP_METADATA_VERSION_ID - Static variable in class com.linkedin.venice.writer.VeniceWriter
This sentinel value indicates that metadata version id is not present.
VENICE_DEFAULT_VALUE_SCHEMA_ID - Static variable in class com.linkedin.venice.writer.VeniceWriter
This sentinel value indicates that value schema id is not present.
VENICE_DISCOVER_URL_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
In single-region mode, this must be a comma-separated list of child controller URLs or d2://<d2ServiceNameForChildController> In multi-region mode, it must be a comma-separated list of parent controller URLs or d2://<d2ServiceNameForParentController>
VENICE_KEY_COUNT - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_LEADER_COMPLETION_STATE_HEADER - Static variable in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
Header to denote whether the leader is completed or not
VENICE_MESSAGE_CLASS - Static variable in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
VENICE_MESSAGE_FIELD - Static variable in class com.linkedin.venice.helix.HelixStatusMessageChannel
 
VENICE_PARENT_CONTROLLER_D2_SERVICE - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
VENICE_PARENT_D2_ZK_HOSTS - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
D2 ZK hosts for Venice Parent Cluster.
VENICE_PARTITIONERS - Static variable in class com.linkedin.venice.ConfigKeys
Specifies a list of partitioners venice supported.
VENICE_PUSH_TYPE - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
VENICE_RE_PUSH_PUSH_ID_PREFIX - Static variable in interface com.linkedin.venice.meta.Version
Prefix used in push id to indicate the version's data source is coming from an existing version topic.
VENICE_REQUEST_RCU - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_RETRY - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_ROUTER_URL - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
 
VENICE_SCHEMA_ID - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_SCHEMA_READER_CONFIG - Static variable in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
Deprecated.
VENICE_STORAGE_CLUSTER_LEADER_HAAS - Static variable in class com.linkedin.venice.ConfigKeys
 
VENICE_STORE - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
Venice store name Samza application is going to produce to.
VENICE_STORE_NAME_PROP - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
VENICE_STORE_VERSION - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_STREAMING - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_STREAMING_RESPONSE - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_SUPPORTED_COMPRESSION_STRATEGY - Static variable in class com.linkedin.venice.HttpConstants
 
VENICE_TRANSPORT_PROTOCOL_HEADER - Static variable in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
 
VENICE_WRITER_CLOSE_FAILED_COUNT - Static variable in class com.linkedin.venice.writer.VeniceWriter
A static counter shared by all VeniceWriter instances to track the number of VeniceWriter that fails to close
VENICE_WRITER_CONFIG_PREFIX - Static variable in class com.linkedin.venice.writer.VeniceWriter
 
VENICE_ZOOKEEPER_URL - com.linkedin.venice.Arg
 
VeniceAbstractPartitionReader - Class in com.linkedin.venice.hadoop.spark.input
 
VeniceAbstractPartitionReader(VeniceProperties, InputPartition) - Constructor for class com.linkedin.venice.hadoop.spark.input.VeniceAbstractPartitionReader
 
VeniceAclException - Exception in com.linkedin.venice.exceptions
A runtime exception which may be thrown by implementation of AuthorizerService interface.
VeniceAclException(String, int) - Constructor for exception com.linkedin.venice.exceptions.VeniceAclException
 
VeniceAclException(String, int, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceAclException
 
VeniceAdminStats - Class in com.linkedin.venice.controller.stats
 
VeniceAdminStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.VeniceAdminStats
 
VeniceAfterImageConsumerImpl<K,​V> - Class in com.linkedin.davinci.consumer
 
VeniceAfterImageConsumerImpl(ChangelogClientConfig, PubSubConsumerAdapter) - Constructor for class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
VeniceAfterImageConsumerImpl(ChangelogClientConfig, PubSubConsumerAdapter, Lazy<VeniceChangelogConsumerImpl<K, V>>) - Constructor for class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
VeniceAvroFileIterator - Class in com.linkedin.venice.hadoop.input.recordreader.avro
 
VeniceAvroFileIterator(FileSystem, Path, AbstractAvroRecordReader<AvroWrapper<IndexedRecord>, NullWritable>) - Constructor for class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
 
VeniceAvroKafkaSerializer - Class in com.linkedin.venice.serialization.avro
This class is a thin wrapper of AvroSerializer and AvroGenericDeserializer.
VeniceAvroKafkaSerializer(String) - Constructor for class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
 
VeniceAvroKafkaSerializer(Schema) - Constructor for class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
 
VeniceAvroMapper - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.map
 
VeniceAvroMapper() - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.map.VeniceAvroMapper
 
VeniceAvroRecordReader - Class in com.linkedin.venice.hadoop.input.recordreader.avro
A record reader that reads records from Avro file input into Avro-serialized keys and values.
VeniceAvroRecordReader(Schema, String, String, ETLValueSchemaTransformation, Schema) - Constructor for class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroRecordReader
This constructor is used when data is read from HDFS.
VeniceChangeCoordinate - Class in com.linkedin.davinci.consumer
 
VeniceChangeCoordinate() - Constructor for class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
VeniceChangeCoordinate(String, PubSubPosition, Integer) - Constructor for class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
VeniceChangelogConsumer<K,​V> - Interface in com.linkedin.davinci.consumer
Venice change capture consumer to provide value change callback.
VeniceChangelogConsumerClientFactory - Class in com.linkedin.davinci.consumer
 
VeniceChangelogConsumerClientFactory(ChangelogClientConfig, MetricsRepository) - Constructor for class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
 
VeniceChangelogConsumerClientFactory.ViewClassGetter - Interface in com.linkedin.davinci.consumer
 
VeniceChangelogConsumerImpl<K,​V> - Class in com.linkedin.davinci.consumer
 
VeniceChangelogConsumerImpl(ChangelogClientConfig, PubSubConsumerAdapter) - Constructor for class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
 
VeniceCheckedRunnable - Interface in com.linkedin.venice.utils
A Runnable that throws checked exceptions.
VeniceCheckedSupplier<T> - Interface in com.linkedin.venice.utils
A Supplier that throws checked exceptions.
VeniceChecksumException - Exception in com.linkedin.venice.exceptions
 
VeniceChecksumException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceChecksumException
 
VeniceChecksumException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceChecksumException
 
VeniceChunkedPayloadTTLFilter - Class in com.linkedin.venice.hadoop.input.kafka.ttl
This class is responsible to filter records based on the RMD information and the ttl config by taking chunked records ChunkAssembler.ValueBytesAndSchemaId.
VeniceChunkedPayloadTTLFilter(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
 
VeniceChunkedResponse - Class in com.linkedin.venice.router.streaming
This is the class to talk to VeniceChunkedWriteHandler to send back partial response.
VeniceChunkedResponse(String, RequestType, ChannelHandlerContext, VeniceChunkedWriteHandler, RouterStats<AggRouterHttpRequestStats>, Optional<Map<CharSequence, String>>) - Constructor for class com.linkedin.venice.router.streaming.VeniceChunkedResponse
 
VeniceChunkedWriteHandler - Class in com.linkedin.venice.router.streaming
This class is the wrapper of ChunkedWriteHandler, and essentially it will introduce the following logic: 1.
VeniceChunkedWriteHandler() - Constructor for class com.linkedin.venice.router.streaming.VeniceChunkedWriteHandler
 
VeniceChunkedWriteHandler.WriteMessageCallback - Interface in com.linkedin.venice.router.streaming
 
VeniceClientBasedMetadata - Class in com.linkedin.venice.fastclient.meta
A store metadata abstraction that uses Venice clients to fetch the metadata and keep the local cache updated.
VeniceClientBasedMetadata(ClientConfig) - Constructor for class com.linkedin.venice.fastclient.meta.VeniceClientBasedMetadata
 
VeniceClientException - Exception in com.linkedin.venice.client.exceptions
Thrown by the venice thin client if something goes wrong with the request Parent class to VeniceClientHttpException
VeniceClientException() - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientException
 
VeniceClientException(String) - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientException
 
VeniceClientException(String, Throwable) - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientException
 
VeniceClientException(Throwable) - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientException
 
VeniceClientHttpException - Exception in com.linkedin.venice.client.exceptions
VeniceClientException with a http code
VeniceClientHttpException(int) - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientHttpException
 
VeniceClientHttpException(String, int) - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientHttpException
 
VeniceClientHttpException(String, int, Throwable) - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientHttpException
 
VeniceClientRateExceededException - Exception in com.linkedin.venice.client.exceptions
 
VeniceClientRateExceededException() - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientRateExceededException
 
VeniceClientRateExceededException(String) - Constructor for exception com.linkedin.venice.client.exceptions.VeniceClientRateExceededException
 
VeniceClientRequest - Class in com.linkedin.venice.protocols
Protobuf type com.linkedin.venice.protocols.VeniceClientRequest
VeniceClientRequest.Builder - Class in com.linkedin.venice.protocols
Protobuf type com.linkedin.venice.protocols.VeniceClientRequest
VeniceClientRequestOrBuilder - Interface in com.linkedin.venice.protocols
 
VeniceClientTlsStrategy - Class in com.linkedin.venice.httpclient5
This class copies most of the logic from DefaultClientTlsStrategy and AbstractClientTlsStrategy to get rid of the cipher check to be backward compatible.
VeniceClientTlsStrategy(SSLContext, String[], String[], SSLBufferMode, HostnameVerifier, Factory<SSLEngine, TlsDetails>) - Constructor for class com.linkedin.venice.httpclient5.VeniceClientTlsStrategy
 
VeniceClientTlsStrategyBuilder - Class in com.linkedin.venice.httpclient5
This class copies most of the logic from ClientTlsStrategyBuilder to get rid of the cipher check while using http/2 in TlsCiphers to be backward compatible.
VeniceClientTlsStrategyBuilder() - Constructor for class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
 
VeniceClusterConfig - Class in com.linkedin.davinci.config
class that maintains config very specific to a Venice cluster
VeniceClusterConfig(VeniceProperties, Map<String, Map<String, String>>) - Constructor for class com.linkedin.davinci.config.VeniceClusterConfig
 
VeniceComponent - Class in com.linkedin.venice.acl
 
VeniceComponent() - Constructor for class com.linkedin.venice.acl.VeniceComponent
 
VeniceCompressor - Class in com.linkedin.venice.compression
 
VeniceCompressor(CompressionStrategy) - Constructor for class com.linkedin.venice.compression.VeniceCompressor
 
VeniceComputePath - Class in com.linkedin.venice.router.api.path
 
VeniceComputePath(String, int, String, BasicFullHttpRequest, VenicePartitionFinder, int, boolean, int, int) - Constructor for class com.linkedin.venice.router.api.path.VeniceComputePath
 
VeniceConcurrentHashMap<K,​V> - Class in com.linkedin.venice.utils.concurrent
 
VeniceConcurrentHashMap() - Constructor for class com.linkedin.venice.utils.concurrent.VeniceConcurrentHashMap
 
VeniceConcurrentHashMap(int) - Constructor for class com.linkedin.venice.utils.concurrent.VeniceConcurrentHashMap
 
VeniceConfigLoader - Class in com.linkedin.davinci.config
VeniceConfigService loads the static configuration that does not change once the Server is started.
VeniceConfigLoader(VeniceProperties) - Constructor for class com.linkedin.davinci.config.VeniceConfigLoader
 
VeniceConfigLoader(VeniceProperties, VeniceProperties) - Constructor for class com.linkedin.davinci.config.VeniceConfigLoader
 
VeniceConfigLoader(VeniceProperties, VeniceProperties, Map<String, Map<String, String>>) - Constructor for class com.linkedin.davinci.config.VeniceConfigLoader
 
VeniceConstants - Class in com.linkedin.venice
 
VeniceConstants() - Constructor for class com.linkedin.venice.VeniceConstants
 
VeniceController - Class in com.linkedin.venice.controller
Venice Controller to manage the cluster.
VeniceController(VeniceControllerContext) - Constructor for class com.linkedin.venice.controller.VeniceController
 
VeniceController(List<VeniceProperties>, MetricsRepository, List<ServiceDiscoveryAnnouncer>, Optional<DynamicAccessController>, Optional<AuthorizerService>, D2Client, Optional<ClientConfig>, Optional<ICProvider>, Optional<SupersetSchemaGenerator>) - Constructor for class com.linkedin.venice.controller.VeniceController
Deprecated.
VeniceControllerClusterConfig - Class in com.linkedin.venice.controller
Configuration which is specific to a Venice cluster used by Venice controller.
VeniceControllerClusterConfig(VeniceProperties) - Constructor for class com.linkedin.venice.controller.VeniceControllerClusterConfig
 
VeniceControllerConfig - Class in com.linkedin.venice.controller
Configuration which is specific to a Venice controller.
VeniceControllerConfig(VeniceProperties) - Constructor for class com.linkedin.venice.controller.VeniceControllerConfig
 
VeniceControllerContext - Class in com.linkedin.venice.controller
VeniceControllerContext contains dependencies required by VeniceController
VeniceControllerContext(VeniceControllerContext.Builder) - Constructor for class com.linkedin.venice.controller.VeniceControllerContext
 
VeniceControllerContext.Builder - Class in com.linkedin.venice.controller
 
VeniceControllerMultiClusterConfig - Class in com.linkedin.venice.controller
 
VeniceControllerMultiClusterConfig(Collection<VeniceProperties>) - Constructor for class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
VeniceControllerMultiClusterConfig(Map<String, VeniceControllerConfig>) - Constructor for class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
 
VeniceControllerService - Class in com.linkedin.venice.controller
A service venice controller.
VeniceControllerService(VeniceControllerMultiClusterConfig, MetricsRepository, boolean, Optional<SSLConfig>, Optional<DynamicAccessController>, Optional<AuthorizerService>, D2Client, Optional<ClientConfig>, Optional<ICProvider>, Optional<SupersetSchemaGenerator>, PubSubTopicRepository, PubSubClientsFactory) - Constructor for class com.linkedin.venice.controller.VeniceControllerService
 
VeniceControllerStateModel - Class in com.linkedin.venice.controller
State model used to handle the change of leader-standby relationship for controllers.
VeniceControllerStateModel(String, ZkClient, HelixAdapterSerializer, VeniceControllerMultiClusterConfig, VeniceHelixAdmin, MetricsRepository, ClusterLeaderInitializationRoutine, RealTimeTopicSwitcher, Optional<DynamicAccessController>, HelixAdminClient) - Constructor for class com.linkedin.venice.controller.VeniceControllerStateModel
 
veniceControllerUrl - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
VeniceDelegateMode - Class in com.linkedin.venice.router.api
This class contains all the ScatterGatherMode being used in Venice Router.
VeniceDelegateMode(VeniceRouterConfig, RouterStats<AggRouterHttpRequestStats>, RouteHttpRequestStats) - Constructor for class com.linkedin.venice.router.api.VeniceDelegateMode
 
VeniceDispatcher - Class in com.linkedin.venice.router.api
 
VeniceDispatcher(VeniceRouterConfig, ReadOnlyStoreRepository, RouterStats<AggRouterHttpRequestStats>, MetricsRepository, StorageNodeClient, RouteHttpRequestStats, AggHostHealthStats, RouterStats<AggRouterHttpRequestStats>) - Constructor for class com.linkedin.venice.router.api.VeniceDispatcher
 
VeniceDistClusterControllerStateModelFactory - Class in com.linkedin.venice.controller
Factory to create VeniceDistClusterControllerStateModel and provide some utility methods to get state model by given cluster.
VeniceDistClusterControllerStateModelFactory(ZkClient, HelixAdapterSerializer, VeniceHelixAdmin, VeniceControllerMultiClusterConfig, MetricsRepository, ClusterLeaderInitializationRoutine, RealTimeTopicSwitcher, Optional<DynamicAccessController>, HelixAdminClient) - Constructor for class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
 
VeniceEnumValue - Interface in com.linkedin.venice.utils
 
VeniceException - Exception in com.linkedin.venice.exceptions
Base exception that all other Venice exceptions extend
VeniceException() - Constructor for exception com.linkedin.venice.exceptions.VeniceException
 
VeniceException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceException
 
VeniceException(String, ErrorType) - Constructor for exception com.linkedin.venice.exceptions.VeniceException
 
VeniceException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceException
 
VeniceException(String, Throwable, ErrorType) - Constructor for exception com.linkedin.venice.exceptions.VeniceException
 
VeniceException(Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceException
 
VeniceFileInputFormat - Class in com.linkedin.venice.hadoop
Custom Input Format with the following specs to be used for the feature PushJobSetting.useMapperToBuildDict with ValidateSchemaAndBuildDictMapper 1.
VeniceFileInputFormat() - Constructor for class com.linkedin.venice.hadoop.VeniceFileInputFormat
 
veniceFilterChain - Variable in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
VeniceFullHttpResponse - Class in com.linkedin.venice.router.api
A specialized DefaultFullHttpResponse object to record the decompression time of the records in the response.
VeniceFullHttpResponse(HttpVersion, HttpResponseStatus, ByteBuf, long) - Constructor for class com.linkedin.venice.router.api.VeniceFullHttpResponse
 
VeniceGrpcServer - Class in com.linkedin.venice.grpc
 
VeniceGrpcServer(VeniceGrpcServerConfig) - Constructor for class com.linkedin.venice.grpc.VeniceGrpcServer
 
VeniceGrpcServerConfig - Class in com.linkedin.venice.grpc
 
VeniceGrpcServerConfig.Builder - Class in com.linkedin.venice.grpc
 
VeniceHdfsInputPartition - Class in com.linkedin.venice.hadoop.spark.input.hdfs
 
VeniceHdfsInputPartition(Path) - Constructor for class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputPartition
 
VeniceHdfsInputPartitionReader - Class in com.linkedin.venice.hadoop.spark.input.hdfs
 
VeniceHdfsInputPartitionReader(VeniceProperties, VeniceHdfsInputPartition) - Constructor for class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputPartitionReader
 
VeniceHdfsInputPartitionReaderFactory - Class in com.linkedin.venice.hadoop.spark.input.hdfs
 
VeniceHdfsInputPartitionReaderFactory(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputPartitionReaderFactory
 
VeniceHdfsInputScan - Class in com.linkedin.venice.hadoop.spark.input.hdfs
 
VeniceHdfsInputScan(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputScan
 
VeniceHdfsInputScanBuilder - Class in com.linkedin.venice.hadoop.spark.input.hdfs
 
VeniceHdfsInputScanBuilder(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputScanBuilder
 
VeniceHdfsInputTable - Class in com.linkedin.venice.hadoop.spark.input.hdfs
A table format that is used by Spark to read Avro files from HDFS for use in VenicePushJob.
VeniceHdfsInputTable(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsInputTable
 
VeniceHdfsSource - Class in com.linkedin.venice.hadoop.spark.input.hdfs
This is the entrypoint of the Avro input source.
VeniceHdfsSource() - Constructor for class com.linkedin.venice.hadoop.spark.input.hdfs.VeniceHdfsSource
 
VeniceHelixAdmin - Class in com.linkedin.venice.controller
Helix Admin based on 0.8.4.215 APIs.
VeniceHelixAdmin(VeniceControllerMultiClusterConfig, MetricsRepository, boolean, D2Client, Optional<SSLConfig>, Optional<DynamicAccessController>, Optional<ICProvider>, PubSubTopicRepository, PubSubClientsFactory, List<ClusterLeaderInitializationRoutine>) - Constructor for class com.linkedin.venice.controller.VeniceHelixAdmin
 
VeniceHelixAdmin(VeniceControllerMultiClusterConfig, MetricsRepository, D2Client, PubSubTopicRepository, PubSubClientsFactory) - Constructor for class com.linkedin.venice.controller.VeniceHelixAdmin
 
VeniceHelixAdmin.StoreMetadataOperation - Interface in com.linkedin.venice.controller
 
VeniceHostFinder - Class in com.linkedin.venice.router.api
{code VeniceHostFinder} finds a set of hosts that can serve the given Venice resource partition.
VeniceHostFinder(OnlineInstanceFinder, RouterStats<AggRouterHttpRequestStats>, HostHealthMonitor<Instance>) - Constructor for class com.linkedin.venice.router.api.VeniceHostFinder
 
VeniceHostHealth - Class in com.linkedin.venice.router.api
VeniceHostHealth the aggregate statistics for HostHealthStats.
VeniceHostHealth(LiveInstanceMonitor, StorageNodeClient, VeniceRouterConfig, RouteHttpRequestStats, AggHostHealthStats) - Constructor for class com.linkedin.venice.router.api.VeniceHostHealth
 
VeniceHttp2PipelineInitializerBuilder - Class in com.linkedin.venice.listener
This utility is used to manage all the HTTP/2 related configs and offer a way to spin up a pipeline to support both HTTP/1.1 and HTTP/2.
VeniceHttp2PipelineInitializerBuilder(VeniceServerConfig) - Constructor for class com.linkedin.venice.listener.VeniceHttp2PipelineInitializerBuilder
 
VeniceHttpException - Exception in com.linkedin.venice.exceptions
 
VeniceHttpException(int) - Constructor for exception com.linkedin.venice.exceptions.VeniceHttpException
 
VeniceHttpException(int, String) - Constructor for exception com.linkedin.venice.exceptions.VeniceHttpException
 
VeniceHttpException(int, String, ErrorType) - Constructor for exception com.linkedin.venice.exceptions.VeniceHttpException
 
VeniceHttpException(int, String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceHttpException
 
VeniceHttpException(int, String, Throwable, ErrorType) - Constructor for exception com.linkedin.venice.exceptions.VeniceHttpException
 
VeniceHttpException(int, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceHttpException
 
VeniceHttpException(int, Throwable, ErrorType) - Constructor for exception com.linkedin.venice.exceptions.VeniceHttpException
 
VeniceInconsistentSchemaException - Exception in com.linkedin.venice.hadoop.exceptions
Customized exception for inconsistent Avro schema error of input directory in VenicePushJob
VeniceInconsistentSchemaException(String) - Constructor for exception com.linkedin.venice.hadoop.exceptions.VeniceInconsistentSchemaException
 
VeniceInconsistentSchemaException(String, Throwable) - Constructor for exception com.linkedin.venice.hadoop.exceptions.VeniceInconsistentSchemaException
 
VeniceInconsistentStoreMetadataException - Exception in com.linkedin.venice.exceptions
This exception is thrown when we detect inconsistent or possibly corrupted store metadata on storage nodes.
VeniceInconsistentStoreMetadataException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceInconsistentStoreMetadataException
 
VeniceIngestionBackend - Interface in com.linkedin.davinci.ingestion
 
VeniceIngestionTaskKilledException - Exception in com.linkedin.venice.exceptions
 
VeniceIngestionTaskKilledException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceIngestionTaskKilledException
 
VeniceIngestionTaskKilledException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceIngestionTaskKilledException
 
VeniceJsonSerializer<T> - Class in com.linkedin.venice.helix
 
VeniceJsonSerializer(TypeReference<T>) - Constructor for class com.linkedin.venice.helix.VeniceJsonSerializer
 
VeniceJsonSerializer(Class<T>) - Constructor for class com.linkedin.venice.helix.VeniceJsonSerializer
 
VeniceJVMStats - Class in com.linkedin.venice.stats
Simple class that spins JVM platform stats into Venice stats.
VeniceJVMStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.VeniceJVMStats
 
VeniceKafkaDecodedRecord - Class in com.linkedin.venice.etl
 
VeniceKafkaDecodedRecord() - Constructor for class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
Default constructor.
VeniceKafkaDecodedRecord(ByteBuffer, ByteBuffer, Long, Long, Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
All-args constructor.
VeniceKafkaInputMapper - Class in com.linkedin.venice.hadoop.input.kafka
This class is designed specifically for KafkaInputFormat, and right now, it is doing simple pass-through.
VeniceKafkaInputMapper() - Constructor for class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
 
VeniceKafkaInputReducer - Class in com.linkedin.venice.hadoop.input.kafka
This class is designed specifically for KafkaInputFormat, and right now, it will pick up the latest entry according to the associated offset, and produce it to Kafka.
VeniceKafkaInputReducer() - Constructor for class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
 
VeniceKafkaInputTTLFilter - Class in com.linkedin.venice.hadoop.input.kafka.ttl
This class is responsible to filter records based on the RMD information and the ttl config by taking KIF input KafkaInputMapperValue.
VeniceKafkaInputTTLFilter(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
 
VeniceKafkaSerializer<T> - Interface in com.linkedin.venice.serialization
Map objects to byte arrays and back again
VeniceKeyCountLimitException - Exception in com.linkedin.venice.router.exception
 
VeniceKeyCountLimitException(String, RequestType, int, int) - Constructor for exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
 
VeniceLock - Class in com.linkedin.venice.utils
Venice wrapper around a Lock object to record metrics and emit logs when lock acquisition is taking too long.
VeniceLock(Lock, String, MetricsRepository) - Constructor for class com.linkedin.venice.utils.VeniceLock
 
VeniceLock(Lock, String, MetricsRepository, long) - Constructor for class com.linkedin.venice.utils.VeniceLock
 
VeniceLockStats - Class in com.linkedin.venice.stats
 
VeniceLockStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.VeniceLockStats
 
VeniceMessageException - Exception in com.linkedin.venice.exceptions
Custom Exception for Venice messages.
VeniceMessageException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceMessageException
 
VeniceMessageException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceMessageException
 
VeniceMetadataRepositoryBuilder - Class in com.linkedin.davinci.repository
VeniceMetadataRepositoryBuilder is a centralized builder class for constructing a variety of metadata components including store repository, schema repository, ZK-shared schema repository, ZK client and cluster info provider for Da Vinci, Venice Service and Isolated Ingestion Service.
VeniceMetadataRepositoryBuilder(VeniceConfigLoader, ClientConfig, MetricsRepository, ICProvider, boolean) - Constructor for class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
 
VeniceMetaDataRequest - Class in com.linkedin.venice.router.httpclient
 
VeniceMetaDataRequest(Instance, String, String, boolean) - Constructor for class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
 
VeniceMetricsProvider - Class in com.linkedin.venice.router.api
This is used to initialize a Metrics for each request.
VeniceMetricsProvider() - Constructor for class com.linkedin.venice.router.api.VeniceMetricsProvider
 
VeniceMRPartitioner - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.partition
VeniceMRPartitioner will use the exact same partitioner as the one that will be used inside VeniceWriter (e.g.
VeniceMRPartitioner() - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
 
VeniceMultiGetPath - Class in com.linkedin.venice.router.api.path
 
VeniceMultiGetPath(String, int, String, BasicFullHttpRequest, VenicePartitionFinder, int, boolean, int, RouterStats<AggRouterHttpRequestStats>, int) - Constructor for class com.linkedin.venice.router.api.path.VeniceMultiGetPath
 
VeniceMultiKeyPath<K> - Class in com.linkedin.venice.router.api.path
 
VeniceMultiKeyPath(String, int, String, boolean, int, int) - Constructor for class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
VeniceMultiKeyPath(String, int, String, boolean, int, Map<RouterKey, K>, int) - Constructor for class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
 
VeniceMultiKeyRoutingStrategy - Enum in com.linkedin.venice.router.api
This enum is used to define various routing strategies for multi-key requests.
VeniceNoClusterException - Exception in com.linkedin.venice.exceptions
 
VeniceNoClusterException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoClusterException
 
VeniceNoClusterException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoClusterException
 
VeniceNoHelixResourceException - Exception in com.linkedin.venice.exceptions
 
VeniceNoHelixResourceException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
 
VeniceNoStoreException - Exception in com.linkedin.venice.exceptions
Thrown when an operation should return information about a store, but the store does not exist
VeniceNoStoreException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
VeniceNoStoreException(String, String) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
VeniceNoStoreException(String, String, String) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
VeniceNoStoreException(String, String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
VeniceNoStoreException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceNoStoreException
 
VeniceNotifier - Interface in com.linkedin.davinci.notifier
Interface for listening to Notifications for Store consumption.
VeniceObjectWithTimestamp - Class in com.linkedin.venice.samza
This class defines a wrapper object to wrap up the actual object and the corresponding update timestamp.
VeniceObjectWithTimestamp(Object, long) - Constructor for class com.linkedin.venice.samza.VeniceObjectWithTimestamp
 
VeniceOfflinePushMonitorAccessor - Class in com.linkedin.venice.helix
Venice implementation of OfflinePushAccessor.
VeniceOfflinePushMonitorAccessor(String, ZkBaseDataAccessor<OfflinePushStatus>, ZkBaseDataAccessor<PartitionStatus>) - Constructor for class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
For testing purpose only.
VeniceOfflinePushMonitorAccessor(String, ZkClient, HelixAdapterSerializer) - Constructor for class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
VeniceOfflinePushMonitorAccessor(String, ZkClient, HelixAdapterSerializer, int, long) - Constructor for class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
 
VeniceParentHelixAdmin - Class in com.linkedin.venice.controller
This class is a wrapper of VeniceHelixAdmin, which will be used in parent controller.
VeniceParentHelixAdmin(VeniceHelixAdmin, VeniceControllerMultiClusterConfig) - Constructor for class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
VeniceParentHelixAdmin(VeniceHelixAdmin, VeniceControllerMultiClusterConfig, boolean, Optional<SSLConfig>, Optional<DynamicAccessController>, Optional<AuthorizerService>, LingeringStoreVersionChecker) - Constructor for class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
VeniceParentHelixAdmin(VeniceHelixAdmin, VeniceControllerMultiClusterConfig, boolean, Optional<SSLConfig>, Optional<DynamicAccessController>, Optional<AuthorizerService>, LingeringStoreVersionChecker, WriteComputeSchemaConverter, Optional<SupersetSchemaGenerator>, PubSubTopicRepository, DelegatingClusterLeaderInitializationRoutine, DelegatingClusterLeaderInitializationRoutine) - Constructor for class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
VeniceParentHelixAdmin(VeniceHelixAdmin, VeniceControllerMultiClusterConfig, boolean, Optional<SSLConfig>, Optional<AuthorizerService>) - Constructor for class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
venicePartitioner - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
venicePartitioner - Variable in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
 
VenicePartitioner - Class in com.linkedin.venice.partitioner
Determines partitioning, which is used for producing messages into the right Kafka partitions and routing reads to the correct Venice storage nodes.
VenicePartitioner() - Constructor for class com.linkedin.venice.partitioner.VenicePartitioner
 
VenicePartitioner(VeniceProperties) - Constructor for class com.linkedin.venice.partitioner.VenicePartitioner
 
VenicePartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.partitioner.VenicePartitioner
 
VenicePartitionFinder - Class in com.linkedin.venice.router.api
VenicePartitionFinder provides methods to find the partition name or number for the given data.
VenicePartitionFinder(RoutingDataRepository, ReadOnlyStoreRepository) - Constructor for class com.linkedin.venice.router.api.VenicePartitionFinder
 
VenicePath - Class in com.linkedin.venice.router.api.path
 
VenicePath(String, int, String, boolean, int) - Constructor for class com.linkedin.venice.router.api.path.VenicePath
 
VenicePath(String, int, String, boolean, int, Time) - Constructor for class com.linkedin.venice.router.api.path.VenicePath
 
VenicePathParser<HTTP_REQUEST extends BasicHttpRequest> - Class in com.linkedin.venice.router.api
Inbound request to the router will look like: /read/storename/key?f=fmt 'read' is a literal, meaning we will request the value for a single key storename will be the name of the requested store key is the key being looked up fmt is an optional format parameter, one of 'string' or 'b64'.
VenicePathParser(VeniceVersionFinder, VenicePartitionFinder, RouterStats<AggRouterHttpRequestStats>, ReadOnlyStoreRepository, VeniceRouterConfig, CompressorFactory) - Constructor for class com.linkedin.venice.router.api.VenicePathParser
 
VenicePathParserHelper - Class in com.linkedin.venice.router.api
Created by mwise on 4/25/16.
VeniceProducer<K,​V> - Interface in com.linkedin.venice.producer
The API for online applications to write to Venice.
VeniceProducerMetrics - Class in com.linkedin.venice.producer
 
VeniceProducerMetrics(MetricsRepository, String) - Constructor for class com.linkedin.venice.producer.VeniceProducerMetrics
 
VeniceProperties - Class in com.linkedin.venice.utils
 
VeniceProperties() - Constructor for class com.linkedin.venice.utils.VeniceProperties
Deprecated.
VeniceProperties(Map<CharSequence, CharSequence>) - Constructor for class com.linkedin.venice.utils.VeniceProperties
 
VeniceProperties(Properties) - Constructor for class com.linkedin.venice.utils.VeniceProperties
 
VenicePulsarSink - Class in com.linkedin.venice.pulsar.sink
A Pulsar Sink that sends messages to Venice.
VenicePulsarSink() - Constructor for class com.linkedin.venice.pulsar.sink.VenicePulsarSink
 
VenicePulsarSinkConfig - Class in com.linkedin.venice.pulsar.sink
Configuration class for the Sink Connector.
VenicePulsarSinkConfig() - Constructor for class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
 
VenicePushJob - Class in com.linkedin.venice.hadoop
This class sets up the Hadoop job used to push data to Venice.
VenicePushJob(String, Properties) - Constructor for class com.linkedin.venice.hadoop.VenicePushJob
 
VenicePushJob.PushJobCheckpoints - Enum in com.linkedin.venice.hadoop
Different successful checkpoints and known error scenarios of the VPJ flow.
VenicePushJobConstants - Class in com.linkedin.venice.hadoop
 
VeniceReadServiceGrpc - Class in com.linkedin.venice.protocols
 
VeniceReadServiceGrpc.VeniceReadServiceBlockingStub - Class in com.linkedin.venice.protocols
 
VeniceReadServiceGrpc.VeniceReadServiceFutureStub - Class in com.linkedin.venice.protocols
 
VeniceReadServiceGrpc.VeniceReadServiceImplBase - Class in com.linkedin.venice.protocols
 
VeniceReadServiceGrpc.VeniceReadServiceStub - Class in com.linkedin.venice.protocols
 
VeniceReadServiceImpl - Class in com.linkedin.venice.listener.grpc
 
VeniceReadServiceImpl(VeniceServerGrpcRequestProcessor) - Constructor for class com.linkedin.venice.listener.grpc.VeniceReadServiceImpl
 
VeniceReadServiceImplBase() - Constructor for class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceImplBase
 
VeniceReadServiceOuterClass - Class in com.linkedin.venice.protocols
 
VeniceRecordIterator - Interface in com.linkedin.venice.hadoop.input.recordreader
 
veniceRecordReader - Variable in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
 
VeniceReducer - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.reduce
VeniceReducer will be in charge of producing the messages to Kafka broker.
VeniceReducer() - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
 
VeniceReentrantReadWriteLock - Class in com.linkedin.venice.utils.concurrent
This class simply exposes publicly the protected methods of its parent, for debugging purposes.
VeniceReentrantReadWriteLock() - Constructor for class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
 
VeniceRequestEarlyTerminationException - Exception in com.linkedin.venice.listener
 
VeniceRequestEarlyTerminationException(String) - Constructor for exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
 
VeniceResource - Interface in com.linkedin.venice
Venice resource that could be refreshed to retrieve the newest data or clear the current data in memory.
VeniceResourceAccessException - Exception in com.linkedin.venice.exceptions
Class for all Venice exceptions that are triggered by Kafka topic authorization related issues.
VeniceResourceAccessException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceResourceAccessException
 
VeniceResourceAccessException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceResourceAccessException
 
VeniceResourceCloseResult - Enum in com.linkedin.venice.utils
 
VeniceResponseAggregator - Class in com.linkedin.venice.router.api
VeniceResponseAggregator aggregates the sub-responses returned by storage node for a multi-get request.
VeniceResponseAggregator(RouterStats<AggRouterHttpRequestStats>, Optional<MetaStoreShadowReader>) - Constructor for class com.linkedin.venice.router.api.VeniceResponseAggregator
 
VeniceResponseCompletableFuture<T> - Class in com.linkedin.venice.client.store.streaming
CompletableFuture implementation to handle partial response.
VeniceResponseCompletableFuture(Supplier<VeniceResponseMap>, int, Optional<ClientStats>) - Constructor for class com.linkedin.venice.client.store.streaming.VeniceResponseCompletableFuture
 
VeniceResponseDecompressor - Class in com.linkedin.venice.router.api
This class is used to handle all the decompression related logic in Router, and it will be used in VeniceResponseAggregator for regular requests and VeniceDispatcher for streaming requests.
VeniceResponseDecompressor(boolean, RouterStats<AggRouterHttpRequestStats>, BasicFullHttpRequest, String, int, CompressorFactory) - Constructor for class com.linkedin.venice.router.api.VeniceResponseDecompressor
 
VeniceResponseMap<K,​V> - Interface in com.linkedin.venice.client.store.streaming
Venice customized map, which could contains either a full response or a partial response.
VeniceResponseMapImpl<K,​V> - Class in com.linkedin.venice.client.store.streaming
 
VeniceResponseMapImpl(Map<K, V>, Queue<K>, boolean) - Constructor for class com.linkedin.venice.client.store.streaming.VeniceResponseMapImpl
 
VeniceRetriableException - Exception in com.linkedin.venice.exceptions
Interface for all Venice exceptions that are retriable.
VeniceRetriableException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceRetriableException
 
VeniceRetriableException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceRetriableException
 
VeniceRmdTTLFilter<INPUT_VALUE> - Class in com.linkedin.venice.hadoop.input.kafka.ttl
This class is responsible to filter records based on the RMD information and the ttl config.
VeniceRmdTTLFilter(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
 
VeniceRole - Enum in com.linkedin.venice.router.api
 
VeniceRoleFinder - Class in com.linkedin.venice.router.api
 
VeniceRoleFinder() - Constructor for class com.linkedin.venice.router.api.VeniceRoleFinder
 
VeniceRouteHandler<T extends ControllerResponse> - Class in com.linkedin.venice.controller.server
Common route handler implement the common part of error handling and writing response to json.
VeniceRouteHandler(Class<T>) - Constructor for class com.linkedin.venice.controller.server.VeniceRouteHandler
 
VeniceRouterConfig - Class in com.linkedin.venice.router
Configuration for Venice Router.
VeniceRouterConfig(VeniceProperties) - Constructor for class com.linkedin.venice.router.VeniceRouterConfig
 
VeniceRouterException - Exception in com.linkedin.venice.exceptions
 
VeniceRouterException() - Constructor for exception com.linkedin.venice.exceptions.VeniceRouterException
 
VeniceRouterException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceRouterException
 
VeniceRouterException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceRouterException
 
VeniceRouterException(Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceRouterException
 
VeniceRouterUtils - Class in com.linkedin.venice.router.utils
 
VeniceRouterUtils() - Constructor for class com.linkedin.venice.router.utils.VeniceRouterUtils
 
VeniceSchemaFieldNotFoundException - Exception in com.linkedin.venice.hadoop.exceptions
Customized exception for non-existing key/value field error in Avro schema in VenicePushJob
VeniceSchemaFieldNotFoundException(String, String) - Constructor for exception com.linkedin.venice.hadoop.exceptions.VeniceSchemaFieldNotFoundException
 
VeniceSerializationException - Exception in com.linkedin.venice.serializer
 
VeniceSerializationException(String) - Constructor for exception com.linkedin.venice.serializer.VeniceSerializationException
 
VeniceSerializationException(String, Throwable) - Constructor for exception com.linkedin.venice.serializer.VeniceSerializationException
 
VeniceSerializer<T> - Interface in com.linkedin.venice.meta
Interface defines how to serialize and deserialize the venice object.
VeniceServer - Class in com.linkedin.venice.server
Class that represents the Venice server.
VeniceServer(VeniceConfigLoader, MetricsRepository, Optional<SSLFactory>, Optional<StaticAccessController>, Optional<DynamicAccessController>, Optional<ClientConfig>, ICProvider, List<ServiceDiscoveryAnnouncer>) - Constructor for class com.linkedin.venice.server.VeniceServer
Deprecated.
Use VeniceServer(VeniceServerContext) instead. Constructor kept for maintaining the backward compatibility Allocates a new VeniceServer object.
VeniceServer(VeniceServerContext) - Constructor for class com.linkedin.venice.server.VeniceServer
 
VeniceServerConfig - Class in com.linkedin.davinci.config
VeniceServerConfig maintains configs specific to Venice Server, Da Vinci client and Isolated Ingestion Service.
VeniceServerConfig(VeniceProperties) - Constructor for class com.linkedin.davinci.config.VeniceServerConfig
 
VeniceServerConfig(VeniceProperties, Map<String, Map<String, String>>) - Constructor for class com.linkedin.davinci.config.VeniceServerConfig
 
VeniceServerContext - Class in com.linkedin.venice.server
VeniceServerContext contains dependencies required by VeniceServer
VeniceServerContext.Builder - Class in com.linkedin.venice.server
 
VeniceServerGrpcHandler - Class in com.linkedin.venice.listener.grpc.handlers
 
VeniceServerGrpcHandler() - Constructor for class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
 
VeniceServerGrpcRequestProcessor - Class in com.linkedin.venice.listener.grpc.handlers
 
VeniceServerGrpcRequestProcessor() - Constructor for class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcRequestProcessor
 
VeniceServerResponse - Class in com.linkedin.venice.protocols
Protobuf type com.linkedin.venice.protocols.VeniceServerResponse
VeniceServerResponse.Builder - Class in com.linkedin.venice.protocols
Protobuf type com.linkedin.venice.protocols.VeniceServerResponse
VeniceServerResponseOrBuilder - Interface in com.linkedin.venice.protocols
 
VeniceSingleGetPath - Class in com.linkedin.venice.router.api.path
 
VeniceSingleGetPath(String, int, String, String, String, VenicePartitionFinder, RouterStats<AggRouterHttpRequestStats>) - Constructor for class com.linkedin.venice.router.api.path.VeniceSingleGetPath
 
VeniceSocketConnectorFactory - Class in com.linkedin.venice.controller.spark
Creates socket connectors.
VeniceSocketConnectorFactory() - Constructor for class com.linkedin.venice.controller.spark.VeniceSocketConnectorFactory
 
VeniceSparkEmbeddedJettyServer - Class in com.linkedin.venice.controller.spark
Spark server implementation
VeniceSparkEmbeddedJettyServer(VeniceProperties, Handler) - Constructor for class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
 
VeniceSparkPartitioner - Class in com.linkedin.venice.hadoop.spark.datawriter.partition
VeniceSparkPartitioner will use the exact same partitioner as the one that will be used inside VeniceWriter (e.g.
VeniceSparkPartitioner(Broadcast<Properties>, int) - Constructor for class com.linkedin.venice.hadoop.spark.datawriter.partition.VeniceSparkPartitioner
 
VeniceSparkServerFactory - Class in com.linkedin.venice.controller.spark
Creates instances of embedded jetty containers.
VeniceSparkServerFactory(VeniceProperties) - Constructor for class com.linkedin.venice.controller.spark.VeniceSparkServerFactory
 
VeniceSpecificDatumReader<T> - Class in com.linkedin.venice.serialization.avro
 
VeniceSpecificDatumReader(Schema, Schema) - Constructor for class com.linkedin.venice.serialization.avro.VeniceSpecificDatumReader
 
VeniceStandalone - Class in com.linkedin.venice.standalone
 
VeniceStandalone() - Constructor for class com.linkedin.venice.standalone.VeniceStandalone
 
VeniceStoreAlreadyExistsException - Exception in com.linkedin.venice.exceptions
Thrown when an operation should create a store, but the store already exists
VeniceStoreAlreadyExistsException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
 
VeniceStoreAlreadyExistsException(String, String) - Constructor for exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
 
VeniceStoreAlreadyExistsException(String, String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
 
VeniceStoreAlreadyExistsException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
 
VeniceStoreCache - Interface in com.linkedin.davinci.store.cache
Interface for a cache on a venice store.
VeniceStoreCacheStorageEngine - Class in com.linkedin.davinci.store.cache
 
VeniceStoreCacheStorageEngine(String, ObjectCacheConfig, Schema, AsyncCacheLoader) - Constructor for class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
 
VeniceStoreCacheStoragePartition - Class in com.linkedin.davinci.store.cache
 
VeniceStoreCacheStoragePartition(Integer, ObjectCacheConfig, RecordDeserializer, AsyncCacheLoader) - Constructor for class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
VeniceStoreCacheStoragePartition(Integer, ObjectCacheConfig, Schema, AsyncCacheLoader) - Constructor for class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
VeniceStoreClientFactory - Interface in com.linkedin.venice.client.factory
 
VeniceStoreClientFactory.ClientConfigUpdater - Interface in com.linkedin.venice.client.factory
 
VeniceStoreClientGlobalConfig - Class in com.linkedin.venice.client
 
VeniceStoreClientGlobalConfig() - Constructor for class com.linkedin.venice.client.VeniceStoreClientGlobalConfig
 
VeniceStoreCreationException - Exception in com.linkedin.venice.hadoop.exceptions
Customized exception for receiving invalid VersionCreationResponse in VenicePushJob
VeniceStoreCreationException(String, String) - Constructor for exception com.linkedin.venice.hadoop.exceptions.VeniceStoreCreationException
 
VeniceStoreCreationException(String, String, Throwable) - Constructor for exception com.linkedin.venice.hadoop.exceptions.VeniceStoreCreationException
 
VeniceStoreDataChangedListener() - Constructor for class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter.VeniceStoreDataChangedListener
 
VeniceStoreIsMigratedException - Exception in com.linkedin.venice.exceptions
Thrown when an operation should return information about a store, but the store is migrated to another cluster
VeniceStoreIsMigratedException(String, String, String) - Constructor for exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
 
VeniceStoreVersionConfig - Class in com.linkedin.davinci.config
class that maintains all properties that are not specific to a venice server and cluster.
VeniceStoreVersionConfig(String, VeniceProperties) - Constructor for class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
VeniceStoreVersionConfig(String, VeniceProperties, PersistenceType) - Constructor for class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
VeniceStoreVersionConfig(String, VeniceProperties, Map<String, Map<String, String>>) - Constructor for class com.linkedin.davinci.config.VeniceStoreVersionConfig
 
VeniceSuiteListener - Class in com.linkedin.venice.testng
 
VeniceSuiteListener() - Constructor for class com.linkedin.venice.testng.VeniceSuiteListener
 
VeniceSystemFactory - Class in com.linkedin.venice.samza
Samza jobs talk to either parent or child controller depending on the aggregate mode config.
VeniceSystemFactory() - Constructor for class com.linkedin.venice.samza.VeniceSystemFactory
 
VeniceSystemProducer - Class in com.linkedin.venice.samza
VeniceSystemProducer defines the interfaces for Samza jobs to send data to Venice stores.
VeniceSystemProducer(String, String, Version.PushType, String, String, boolean, VeniceSystemFactory, Optional<SSLFactory>, Optional<String>, Time) - Constructor for class com.linkedin.venice.samza.VeniceSystemProducer
 
VeniceSystemProducer(String, String, String, Version.PushType, String, String, boolean, VeniceSystemFactory, Optional<SSLFactory>, Optional<String>) - Constructor for class com.linkedin.venice.samza.VeniceSystemProducer
Deprecated.
VeniceSystemProducer(String, String, String, Version.PushType, String, String, boolean, VeniceSystemFactory, Optional<SSLFactory>, Optional<String>, Time) - Constructor for class com.linkedin.venice.samza.VeniceSystemProducer
Deprecated.
VeniceSystemProducer(String, String, String, String, Version.PushType, String, String, boolean, VeniceSystemFactory, Optional<SSLFactory>, Optional<String>) - Constructor for class com.linkedin.venice.samza.VeniceSystemProducer
Construct a new instance of VeniceSystemProducer.
VeniceSystemProducer(String, String, String, String, Version.PushType, String, String, boolean, VeniceSystemFactory, Optional<SSLFactory>, Optional<String>, Time) - Constructor for class com.linkedin.venice.samza.VeniceSystemProducer
Construct a new instance of VeniceSystemProducer
VeniceSystemStoreType - Enum in com.linkedin.venice.common
Enum used to differentiate the different types of Venice system stores when access their metadata.
VeniceSystemStoreUtils - Class in com.linkedin.venice.common
 
VeniceSystemStoreUtils() - Constructor for class com.linkedin.venice.common.VeniceSystemStoreUtils
 
VeniceTestListener - Class in com.linkedin.venice.testng
 
VeniceTestListener() - Constructor for class com.linkedin.venice.testng.VeniceTestListener
 
VeniceTimeoutException - Exception in com.linkedin.venice.exceptions
Used when timeout happens in Venice.
VeniceTimeoutException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceTimeoutException
 
VeniceTimeoutException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceTimeoutException
 
VeniceUnsupportedOperationException - Exception in com.linkedin.venice.exceptions
 
VeniceUnsupportedOperationException(String) - Constructor for exception com.linkedin.venice.exceptions.VeniceUnsupportedOperationException
 
VeniceUnsupportedOperationException(String, String) - Constructor for exception com.linkedin.venice.exceptions.VeniceUnsupportedOperationException
 
VeniceUnsupportedOperationException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.VeniceUnsupportedOperationException
 
VeniceUserStoreType - Enum in com.linkedin.venice.meta
Enums that lists most Venice user store types.
VeniceValidationException - Exception in com.linkedin.venice.hadoop.exceptions
Customized exception for validation error for targeted colo push in VenicePushJob
VeniceValidationException(String) - Constructor for exception com.linkedin.venice.hadoop.exceptions.VeniceValidationException
 
VeniceValidationException(String, Throwable) - Constructor for exception com.linkedin.venice.hadoop.exceptions.VeniceValidationException
 
VeniceVersionedStats<STATS,​STATS_REPORTER extends AbstractVeniceStatsReporter<STATS>> - Class in com.linkedin.davinci.stats
 
VeniceVersionedStats(MetricsRepository, String, Supplier<STATS>, StatsSupplier<STATS_REPORTER>) - Constructor for class com.linkedin.davinci.stats.VeniceVersionedStats
 
VeniceVersionedStatsReporter<STATS,​STATS_REPORTER extends AbstractVeniceStatsReporter<STATS>> - Class in com.linkedin.davinci.stats
 
VeniceVersionedStatsReporter(MetricsRepository, String, StatsSupplier<STATS_REPORTER>) - Constructor for class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
 
VeniceVersionFinder - Class in com.linkedin.venice.router.api
VeniceVersionFinder provides methods to find the version for a given store.
VeniceVersionFinder(ReadOnlyStoreRepository, HelixBaseRoutingRepository, StaleVersionStats, HelixReadOnlyStoreConfigRepository, Map<String, String>, String, CompressorFactory, MetricsRepository) - Constructor for class com.linkedin.venice.router.api.VeniceVersionFinder
 
VeniceView - Class in com.linkedin.venice.views
This is the abstract implementation of the 'management' component for a venice view.
VeniceView(Properties, Store, Map<String, String>) - Constructor for class com.linkedin.venice.views.VeniceView
 
VeniceViewWriter - Class in com.linkedin.davinci.store.view
This class is kept separate from the VeniceView class to not leak certain concepts that currently exclusively reside in the server to other components.
VeniceViewWriter(VeniceConfigLoader, Store, Schema, Map<String, String>) - Constructor for class com.linkedin.davinci.store.view.VeniceViewWriter
 
VeniceViewWriterFactory - Class in com.linkedin.davinci.store.view
 
VeniceViewWriterFactory(VeniceConfigLoader) - Constructor for class com.linkedin.davinci.store.view.VeniceViewWriterFactory
 
VeniceVsonFileIterator - Class in com.linkedin.venice.hadoop.input.recordreader.vson
 
VeniceVsonFileIterator(FileSystem, Path, VeniceVsonRecordReader) - Constructor for class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
 
VeniceVsonMapper - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.map
Mapper that reads Vson input and deserializes it as Avro object and then Avro binary
VeniceVsonMapper() - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.map.VeniceVsonMapper
 
VeniceVsonRecordReader - Class in com.linkedin.venice.hadoop.input.recordreader.vson
A record reader that reads records from VSON SequenceFile file input into Avro-serialized keys and values.
VeniceVsonRecordReader(VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
 
VeniceVsonRecordReader(String, String, String, String) - Constructor for class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
 
VeniceVsonRecordReader(String, String, FileSystem, Path) - Constructor for class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
 
veniceWriter - Variable in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
N.B.: With L/F+native replication and many Leader partitions getting assigned to a single SN this VeniceWriter may be called from multiple thread simultaneously, during start of batch push.
VeniceWriter<K,​V,​U> - Class in com.linkedin.venice.writer
Class which acts as the primary writer API.
VeniceWriter(VeniceWriterOptions, VeniceProperties, PubSubProducerAdapter) - Constructor for class com.linkedin.venice.writer.VeniceWriter
 
VeniceWriter(VeniceWriterOptions, VeniceProperties, PubSubProducerAdapter, Schema) - Constructor for class com.linkedin.venice.writer.VeniceWriter
This constructor is currently used only in tests, in order to override the behavior of passing the protocol schema into the header of control messages.
VeniceWriter.KeyProvider - Interface in com.linkedin.venice.writer
An interface which enables the key to contain parts of the {@param producerMetadata} within it, which is useful for control messages and chunked values.
VeniceWriterFactory - Class in com.linkedin.venice.writer
Factory used to create VeniceWriter.
VeniceWriterFactory(Properties) - Constructor for class com.linkedin.venice.writer.VeniceWriterFactory
 
VeniceWriterFactory(Properties, PubSubProducerAdapterFactory, MetricsRepository) - Constructor for class com.linkedin.venice.writer.VeniceWriterFactory
 
VeniceWriterFactory(Properties, MetricsRepository) - Constructor for class com.linkedin.venice.writer.VeniceWriterFactory
 
VeniceWriterMessage(byte[], byte[], int, int, ByteBuffer, PubSubProducerCallback, boolean, int) - Constructor for class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
 
VeniceWriterMessage(byte[], byte[], int, PubSubProducerCallback, boolean, int) - Constructor for class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
 
VeniceWriterOptions - Class in com.linkedin.venice.writer
VeniceWriterOptions is used to pass arguments to VeniceWriter constructor.
VeniceWriterOptions.Builder - Class in com.linkedin.venice.writer
 
VeniceWriterStats - Class in com.linkedin.venice.stats
A host level metric to track number of active venice writers.
VeniceWriterStats(MetricsRepository) - Constructor for class com.linkedin.venice.stats.VeniceWriterStats
 
verify() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext.Builder
 
verifyApiVersion(HttpHeaders, String) - Static method in class com.linkedin.venice.listener.request.GetRouterRequest
throws VeniceException if we don't handle the specified api version
verifyConfig(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
Check whether current storage partition verifyConfig the given partition config
verifyConfig(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
 
verifyConfig(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
 
verifyConfig(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
 
verifyConfig(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
verifyDCConfigNativeAndActiveRepl(String, boolean, boolean, ControllerClient...) - Static method in class com.linkedin.venice.utils.TestUtils
 
verifyHybridStoreDataReplicationPolicy(String, DataReplicationPolicy, ControllerClient...) - Static method in class com.linkedin.venice.utils.TestUtils
 
verifyPersistenceType(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.StorageEngineFactory
 
verifyPersistenceType(AbstractStorageEngine) - Method in class com.linkedin.davinci.store.StorageEngineFactory
 
verifySchemaVersionPresentOrExit() - Method in class com.linkedin.venice.serialization.avro.SchemaPresenceChecker
 
verifySchemaVersionPresentOrExit(Optional<Integer>, boolean) - Method in class com.linkedin.venice.serialization.avro.SchemaPresenceChecker
When schema is present this returns nothing, otherwise it throws an exception and exits the JVM.
VerifySslHandler - Class in com.linkedin.venice.listener
Currently this VerifySslHandler is only used in servers or the isolated ingestion process.
VerifySslHandler() - Constructor for class com.linkedin.venice.listener.VerifySslHandler
 
verifyStoreVersionIsReadyForDataRecovery(String, String, int, int) - Method in class com.linkedin.venice.controller.datarecovery.DataRecoveryManager
Verify that target store version is ready for data recovery.
verifyTransition(ExecutionStatus, ExecutionStatus...) - Static method in class com.linkedin.venice.utils.Utils
Verify that is the new status allowed to be used.
verifyWhetherFastGenericDeserializerWorks() - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
Verify whether fast-avro could generate a fast generic deserializer, but there is no guarantee that the success of all other fast generic deserializer generation in the future.
verifyWhetherFastSpecificDeserializerWorks(Class<? extends SpecificRecord>) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
Verify whether fast-avro could generate a fast specific deserializer, but there is no guarantee that the success of all other fast specific deserializer generation in the future.
version - Variable in class com.linkedin.venice.hadoop.PushJobSetting
Version part of the store-version / topic name
version - Variable in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
The version of current incremental push.
version - Variable in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
The version of current incremental push.
version - Variable in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
The version of current incremental push
Version - Interface in com.linkedin.venice.meta
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
VERSION - com.linkedin.venice.Arg
 
VERSION - com.linkedin.venice.controllerapi.routes.V1Delete
 
VERSION - com.linkedin.venice.controllerapi.routes.V1Get
 
VERSION - com.linkedin.venice.controllerapi.routes.V1Post
 
VERSION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
VERSION_SEPARATOR - Static variable in interface com.linkedin.venice.meta.Version
 
VERSION_SWAP - com.linkedin.venice.kafka.protocol.enums.ControlMessageType
 
VERSION_TOPIC - com.linkedin.venice.pubsub.api.PubSubTopicType
 
VERSION_TOPIC_END_OFFSET_REWIND_COUNT - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
Version.PushType - Enum in com.linkedin.venice.meta
Producer type for writing data to Venice
VersionBackend - Class in com.linkedin.davinci
 
VersionCreationResponse - Class in com.linkedin.venice.controllerapi
 
VersionCreationResponse() - Constructor for class com.linkedin.venice.controllerapi.VersionCreationResponse
 
versionedDIVStats - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
versionedIngestionStats - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
VersionImpl - Class in com.linkedin.venice.meta
Class defines the version of Venice store.
VersionImpl(String, int) - Constructor for class com.linkedin.venice.meta.VersionImpl
Deprecated.
VersionImpl(String, int, long, String, int, PartitionerConfig, DataRecoveryVersionConfig) - Constructor for class com.linkedin.venice.meta.VersionImpl
 
VersionImpl(String, int, String) - Constructor for class com.linkedin.venice.meta.VersionImpl
 
VersionImpl(String, int, String, int) - Constructor for class com.linkedin.venice.meta.VersionImpl
 
versionMetadata - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
The current version number and other version properties such as the compression strategy
versionNum - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
versionNum - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
versionNumber - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
versionNumber - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
versionNumber - Variable in class com.linkedin.venice.router.api.path.VenicePath
 
versionNumber - Variable in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
VersionProperties - Class in com.linkedin.venice.metadata.response
 
VersionProperties() - Constructor for class com.linkedin.venice.metadata.response.VersionProperties
Default constructor.
VersionProperties(Integer, Integer, Integer, CharSequence, Map<CharSequence, CharSequence>, Integer) - Constructor for class com.linkedin.venice.metadata.response.VersionProperties
All-args constructor.
VersionResponse - Class in com.linkedin.venice.controllerapi
 
VersionResponse() - Constructor for class com.linkedin.venice.controllerapi.VersionResponse
 
VersionRoute - Class in com.linkedin.venice.controller.server
 
VersionRoute(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.VersionRoute
 
versions - Variable in class com.linkedin.venice.metadata.response.MetadataResponseRecord
List of all version numbers
versions - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
List of non-retired versions.
versions - Variable in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
VERSIONS - com.linkedin.venice.controllerapi.routes.V1Get
 
VersionSerializerMixin(String, int, long) - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer.VersionSerializerMixin
 
versionsForStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
 
versionsForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
 
versionsForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
versionSpecificCompressorExists(String) - Method in class com.linkedin.venice.compression.CompressorFactory
 
VersionStatus - Enum in com.linkedin.venice.meta
Enums of status of verion.
VersionSwap - Class in com.linkedin.venice.kafka.protocol
This controlMessage is written to the real-time topic by the controller or to the store-version topic by the current version's leader server.
VersionSwap() - Constructor for class com.linkedin.venice.kafka.protocol.VersionSwap
Default constructor.
VersionSwap(CharSequence, CharSequence, List<Long>, Boolean, Boolean) - Constructor for class com.linkedin.venice.kafka.protocol.VersionSwap
All-args constructor.
versionSwapDeferred - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
Indicates if swapping this version to current version after push completion should be initiated or not
versionSwapDetectionIntervalTimeInMs - Variable in class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
 
versionTopic - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
versionTopicToTopicPartitionToConsumer - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
 
viableWithResult(RepushViabilityInfo.Result) - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
 
VIEW_CLASS - com.linkedin.venice.Arg
 
VIEW_NAME - com.linkedin.venice.Arg
 
VIEW_PARAMS - com.linkedin.venice.Arg
 
VIEW_TOPIC - com.linkedin.venice.pubsub.api.PubSubTopicType
 
viewClassGetter - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
 
viewClassName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
This informs what kind of view we are materializing.
viewClassName - Variable in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
This informs what kind of view we are materializing.
ViewConfig - Interface in com.linkedin.venice.meta
 
ViewConfigImpl - Class in com.linkedin.venice.meta
 
ViewConfigImpl(StoreViewConfig) - Constructor for class com.linkedin.venice.meta.ViewConfigImpl
 
ViewConfigImpl(String, Map<String, String>) - Constructor for class com.linkedin.venice.meta.ViewConfigImpl
 
ViewConfigSerializerMixin(String, Map<String, String>) - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer.ViewConfigSerializerMixin
 
viewParameters - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
Optional parameters to be passed to the given view config.
viewParameters - Variable in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
Optional parameters to be passed to the given view config.
viewParameters - Variable in class com.linkedin.venice.views.VeniceView
 
views - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
A map of views which describe and configure a downstream view of a venice store.
views - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
A map of views which describe and configure a downstream view of a venice store.
views - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
A list of views which describe and configure a downstream view of a venice store.
ViewUtils - Class in com.linkedin.venice.views
 
ViewUtils() - Constructor for class com.linkedin.venice.views.ViewUtils
 
viewWriters - Variable in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
ViewWriterUtils - Class in com.linkedin.davinci.store.view
 
ViewWriterUtils() - Constructor for class com.linkedin.davinci.store.view.ViewWriterUtils
 
VIPRequestHandler - Class in com.linkedin.alpini.netty4.handlers
 
VIPRequestHandler(String) - Constructor for class com.linkedin.alpini.netty4.handlers.VIPRequestHandler
 
VIPRequestHandler.State - Enum in com.linkedin.alpini.netty4.handlers
 
visit(long, String, Class<?>, String, Object[]) - Method in interface com.linkedin.alpini.base.misc.TouchTimer.Visitor
 
voidListener(Promise<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
 
VOLDEMORT_STORE - com.linkedin.venice.Arg
 
VOLDEMORT_STORE_NAME - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
vpjEntryClass - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
VPJSSLUtils - Class in com.linkedin.venice.hadoop.utils
This class contains some utils methods for VPJ jobs to obtain SSL-related configs.
VPJSSLUtils() - Constructor for class com.linkedin.venice.hadoop.utils.VPJSSLUtils
 
VSON_PUSH - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Deprecated.
VSON_STORE - com.linkedin.venice.Arg
 
VsonAvroDatumReader<D> - Class in com.linkedin.venice.schema.vson
Deprecated.
VsonAvroDatumReader(Schema) - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
VsonAvroDatumReader(Schema, Schema) - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader
Deprecated.
 
VsonAvroDatumReader.DeepEqualsArrayList - Class in com.linkedin.venice.schema.vson
Deprecated.
This class supports the special byte[] check.
VsonAvroDatumReader.DeepEqualsHashMap - Class in com.linkedin.venice.schema.vson
Deprecated.
This class supports the special byte[] check.
VsonAvroDatumWriter<K> - Class in com.linkedin.venice.schema.vson
Deprecated.
VsonAvroDatumWriter(Schema) - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumWriter
Deprecated.
 
VsonAvroGenericDeserializer<K> - Class in com.linkedin.venice.serializer
 
VsonAvroGenericDeserializer(Schema, Schema) - Constructor for class com.linkedin.venice.serializer.VsonAvroGenericDeserializer
 
VsonAvroGenericSerializer<K> - Class in com.linkedin.venice.serializer
 
VsonAvroGenericSerializer(Schema) - Constructor for class com.linkedin.venice.serializer.VsonAvroGenericSerializer
 
VsonAvroSchemaAdapter - Class in com.linkedin.venice.schema.vson
Deprecated.
VsonAvroSerializer - Class in com.linkedin.venice.schema.vson
Deprecated.
VsonGenericStoreClientImpl<K,​V> - Class in com.linkedin.venice.client.store
Deprecated.
VsonGenericStoreClientImpl(TransportClient, ClientConfig) - Constructor for class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
Deprecated.
 
vsonInputKeySchema - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
vsonInputKeySchemaString - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
vsonInputValueSchema - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
vsonInputValueSchemaString - Variable in class com.linkedin.venice.hadoop.PushJobSetting
 
VsonReader - Class in com.linkedin.venice.schema.vson
Deprecated.
VsonReader(Reader) - Constructor for class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
VsonReader(Reader, int) - Constructor for class com.linkedin.venice.schema.vson.VsonReader
Deprecated.
 
VsonSchema - Class in com.linkedin.venice.schema.vson
Deprecated.
VsonSchema(Object) - Constructor for class com.linkedin.venice.schema.vson.VsonSchema
Deprecated.
 
VsonSchemaAdapter - Class in com.linkedin.venice.schema.vson
Deprecated.
VsonSequenceFileInputFormat - Class in com.linkedin.venice.hadoop
This class was originally from Voldemort.
VsonSequenceFileInputFormat() - Constructor for class com.linkedin.venice.hadoop.VsonSequenceFileInputFormat
 
VsonSerializationException - Exception in com.linkedin.venice.serializer
 
VsonSerializationException() - Constructor for exception com.linkedin.venice.serializer.VsonSerializationException
 
VsonSerializationException(String) - Constructor for exception com.linkedin.venice.serializer.VsonSerializationException
 
VsonSerializationException(String, Throwable) - Constructor for exception com.linkedin.venice.serializer.VsonSerializationException
 
VsonSerializationException(Throwable) - Constructor for exception com.linkedin.venice.serializer.VsonSerializationException
 
VsonTypes - Enum in com.linkedin.venice.schema.vson
Deprecated.

W

WAIT - com.linkedin.venice.hooks.StoreVersionLifecycleEventOutcome
Re-invoke the hook again some time in the future.
WAIT_ALL_REPLICAS - com.linkedin.venice.meta.OfflinePushStrategy
 
WAIT_N_MINUS_ONE_REPLCIA_PER_PARTITION - com.linkedin.venice.meta.OfflinePushStrategy
 
WAIT_TIME_BETWEEN_SCHEMA_READER_ATTEMPTS_IN_MS - Static variable in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
 
WaitAllPushStatusDecider - Class in com.linkedin.venice.pushmonitor
Wait all strategy stands for Venice do not allow one replica to be failed.
WaitAllPushStatusDecider() - Constructor for class com.linkedin.venice.pushmonitor.WaitAllPushStatusDecider
 
waitConsumptionCompleted(String, StateModelIngestionProgressNotifier) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
 
waitExecutorTermination(long, TimeUnit) - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
 
waitExecutorTermination(long, TimeUnit) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelDualPoolFactory
 
waitFor() - Method in class com.linkedin.alpini.io.ExternalCommand
Properly waits until everything is complete: joins on the thread that reads the output, joins on the thread that reads the error and finally wait for the process to be finished.
waitFor() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
 
waitFor(long) - Method in class com.linkedin.alpini.io.ExternalCommand
Properly waits until everything is complete: joins on the thread that reads the output, joins on the thread that reads the error and finally wait for the process to be finished.
waitFor(long, TimeUnit) - Method in class com.linkedin.alpini.io.ExternalCommand
Properly waits until everything is complete: joins on the thread that reads the output, joins on the thread that reads the error and finally wait for the process to be finished.
waitFor(BooleanSupplier, long, TimeUnit) - Static method in enum com.linkedin.alpini.base.test.TestUtil
 
waitForAllMessageToBeProcessedFromTopicPartition(PubSubTopicPartition, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
Besides draining messages in the drainer queue, wait for the last producer future.
waitForAllMessageToBeProcessedFromTopicPartition(PubSubTopicPartition, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
The purpose of this function is to wait for the complete processing (including persistence to disk) of all the messages those were consumed from this kafka {topic, partition} prior to calling this function.
waitForLastLeaderPersistFuture(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
 
waitForNonDeterministicAssertion(long, TimeUnit, boolean, boolean, TestUtils.NonDeterministicAssertion) - Static method in class com.linkedin.venice.utils.TestUtils
 
waitForNonDeterministicAssertion(long, TimeUnit, boolean, TestUtils.NonDeterministicAssertion) - Static method in class com.linkedin.venice.utils.TestUtils
 
waitForNonDeterministicAssertion(long, TimeUnit, TestUtils.NonDeterministicAssertion) - Static method in class com.linkedin.venice.utils.TestUtils
To be used for tests when we need to wait for an async operation to complete.
waitForNonDeterministicCompletion(long, TimeUnit, BooleanSupplier) - Static method in class com.linkedin.venice.utils.TestUtils
To be used for tests when we need to wait for an async operation to complete.
waitForNonDeterministicPushCompletion(String, ControllerClient, long, TimeUnit) - Static method in class com.linkedin.venice.utils.TestUtils
Wait for the push job for a store version or topic to be completed.
waitForShutdown() - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
Waits for shutdown to complete
waitForShutdown() - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
Waits for shutdown to complete
waitForShutdown() - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
waitForShutdown() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Waits for shutdown to complete
waitForShutdown() - Method in interface com.linkedin.alpini.base.registry.Shutdownable
Waits for shutdown to complete
waitForShutdown() - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
 
waitForShutdown() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
waitForShutdown() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
 
waitForShutdown() - Method in class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
Waits for shutdown to complete
waitForShutdown() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
Waits for shutdown to complete
waitForShutdown(long) - Method in class com.linkedin.alpini.base.pool.impl.AsyncPoolImpl
Waits for shutdown to complete with a timeout
waitForShutdown(long) - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
Waits for shutdown to complete with a timeout
waitForShutdown(long) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
waitForShutdown(long) - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Waits for shutdown to complete with a timeout
waitForShutdown(long) - Method in interface com.linkedin.alpini.base.registry.Shutdownable
Waits for shutdown to complete with a timeout
waitForShutdown(long) - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
 
waitForShutdown(long) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableEventLoopGroup
 
waitForShutdown(long) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableHashedWheelTimer
 
waitForShutdown(long) - Method in class com.linkedin.alpini.netty4.misc.ShutdownableNioEventLoopGroup
Waits for shutdown to complete with a timeout
waitForShutdown(long) - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
Waits for shutdown to complete with a timeout
waitIngestionTaskToCompleteAllPartitionPendingActions(String, int, long, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
 
WaitNMinusOnePushStatusDecider - Class in com.linkedin.venice.pushmonitor
Wait N-1 strategy stands for Venice could tolerate one of replica to be failed for each partition.
WaitNMinusOnePushStatusDecider() - Constructor for class com.linkedin.venice.pushmonitor.WaitNMinusOnePushStatusDecider
 
waitPortBinding(int, int) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
waitPortBinding is used to test server port binding in other process.
waitStoreVersionOrThrow(String, ReadOnlyStoreRepository) - Static method in class com.linkedin.venice.utils.Utils
 
waitToStartShutdown() - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Waits until another caller calls ResourceRegistry.shutdown() on this resource registry.
waitToStartShutdown(long) - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
Waits until another caller calls ResourceRegistry.shutdown() on this resource registry.
waitUntilTopicCreated(PubSubTopic, int, long) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
 
waitVersion(String, int, Duration) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
Wait for a specified store/version to appear in the Store Repository and retrieve them.
waitVersion(String, int, Duration, long) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
 
waitVersionStateAvailable(String) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
wantMoreThanOneHttp2Connection() - Method in class com.linkedin.alpini.netty4.pool.Http2AwareChannelPool
 
warn(CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, CharSequence) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, CharSequence, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, Object, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object...) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Object, Object, Object, Object, Object, Object, Object, Object, Object, Object) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, String, Supplier<?>...) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, Message) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Marker, Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Message) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Message, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(MessageSupplier) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(MessageSupplier, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Supplier<?>) - Method in class com.linkedin.alpini.log.FastLogger
 
warn(Supplier<?>, Throwable) - Method in class com.linkedin.alpini.log.FastLogger
 
WARN - Static variable in class com.linkedin.alpini.consts.Level
The WARN level designates potentially harmful situations.
WARN_INT - Static variable in class com.linkedin.alpini.consts.Level
 
WARNING - com.linkedin.venice.pushmonitor.ExecutionStatus
Deprecated.
WEBSITE_URL - com.linkedin.venice.utils.TestWriteUtils.TestTargetedField
 
Welfords - Class in com.linkedin.alpini.base.statistics
Welford's algorithm for calculating variance.
Welfords() - Constructor for class com.linkedin.alpini.base.statistics.Welfords
 
Welfords(Welfords) - Constructor for class com.linkedin.alpini.base.statistics.Welfords
 
Welfords.DoubleWelford - Class in com.linkedin.alpini.base.statistics
 
Welfords.LongWelford - Class in com.linkedin.alpini.base.statistics
 
Welfords.Result - Class in com.linkedin.alpini.base.statistics
 
whenComplete(BiConsumer<? super T, ? super Throwable>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
whenComplete(BiConsumer<? super V, ? super Throwable>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>, Executor) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
 
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
whenCompleteAsync(BiConsumer<? super V, ? super Throwable>, Executor) - Method in class com.linkedin.alpini.base.concurrency.CompletableFutureTask
whetherEnableBatchPushFromAdmin(String) - Method in interface com.linkedin.venice.controller.Admin
 
whetherEnableBatchPushFromAdmin(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Test if a store is allowed for a batch push.
whetherEnableBatchPushFromAdmin(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
whetherStoreReadyToBeCleanup(Store, long, Time) - Static method in class com.linkedin.venice.controller.StoreBackupVersionCleanupService
 
whetherToSkipMessage(Object, ChannelPromise) - Method in interface com.linkedin.venice.router.streaming.VeniceChunkedWriteHandler.WriteMessageCallback
 
WILDCARD_MATCH_ANY - Static variable in interface com.linkedin.venice.utils.PathResourceRegistry
 
WILDCARD_MATCH_ANY - Static variable in class com.linkedin.venice.utils.Utils
 
WILL_FAIL_PUSH - com.linkedin.venice.controller.NodeRemovableResult.BlockingRemoveReason
 
WILL_LOSE_DATA - com.linkedin.venice.controller.NodeRemovableResult.BlockingRemoveReason
 
WILL_TRIGGER_LOAD_REBALANCE - com.linkedin.venice.controller.NodeRemovableResult.BlockingRemoveReason
 
WINDOWS - com.linkedin.alpini.jna.ThreadUtils.OsPlatform
 
WIPE_CLUSTER - com.linkedin.venice.Command
 
WIPE_CLUSTER - com.linkedin.venice.controllerapi.ControllerRoute
 
wipeCluster(Admin) - Method in class com.linkedin.venice.controller.server.ClusterRoutes
 
wipeCluster(String, String, Optional<String>, Optional<Integer>) - Method in interface com.linkedin.venice.controller.Admin
 
wipeCluster(String, String, Optional<String>, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Delete stores from the cluster including both store data and metadata.
wipeCluster(String, String, Optional<String>, Optional<Integer>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
Delete stores from the cluster by sending a ControllerClient.wipeCluster(String, Optional, Optional) request.
wipeCluster(String, Optional<String>, Optional<Integer>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
WITH_CHUNK_MANIFEST - com.linkedin.venice.chunking.ChunkKeyValueTransformer.KeyType
 
WITH_FULL_VALUE - com.linkedin.venice.chunking.ChunkKeyValueTransformer.KeyType
 
WITH_GCM_CIPHERS - Static variable in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
Modern ciphers as used for HTTP/2 plus three weak ciphers as used within LNKD HTTP/1
WITH_VALUE_CHUNK - com.linkedin.venice.chunking.ChunkKeyValueTransformer.KeyType
 
withComputeTardyThreshold(long, TimeUnit) - Method in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
withInitial(Supplier<? extends S>) - Static method in class com.linkedin.alpini.base.misc.SoftThreadLocal
Creates a thread local variable.
withMultiGetTardyThreshold(long, TimeUnit) - Method in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
withoutStackTrace(T) - Static method in enum com.linkedin.alpini.base.misc.ExceptionUtil
 
withRemovedInstance(String) - Method in class com.linkedin.venice.meta.Partition
Remove the given instance from this partition.
withSingleGetTardyThreshold(long, TimeUnit) - Method in class com.linkedin.venice.router.api.VeniceResponseAggregator
 
withThreadPool(ThreadPool) - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
Sets optional thread pool for jetty server.
withThreadPool(ThreadPool) - Method in class com.linkedin.venice.controller.spark.VeniceSparkServerFactory
Sets optional thread pool for jetty server.
workerExecutor(Executor) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
 
workerExecutor(Executor) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
 
wrap(byte[]) - Static method in class com.linkedin.davinci.utils.ByteArrayKey
 
wrap(SyncShutdownable) - Static method in class com.linkedin.alpini.base.registry.SyncShutdownableAdapter
 
wrap(PartitionDispatchHandler4<H, P, K>) - Static method in interface com.linkedin.alpini.router.api.PartitionDispatchHandler4
 
wrap(ResourcePathParser<P, K>) - Static method in interface com.linkedin.alpini.router.api.ExtendedResourcePathParser
 
wrap(StreamingCallback<K, V>) - Static method in class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
 
wrap(Set<T>) - Static method in class com.linkedin.venice.utils.ComplementSet
This API will reuse the input "elements" which cannot be unmodifiable.
writableBytes() - Method in class com.linkedin.alpini.base.safealloc.DerivedReadOnlyByteBuf
 
write(byte[]) - Method in class com.linkedin.alpini.io.CompressOutputStream
Writes b.length bytes to this output stream.
write(byte[]) - Method in class com.linkedin.alpini.io.MeteredOutputStream
Writes b.length bytes to this output stream.
write(byte[]) - Method in class com.linkedin.alpini.io.NullOutputStream
 
write(byte[], int, int) - Method in class com.linkedin.alpini.io.CompressOutputStream
Writes len bytes from the specified byte array starting at offset off to this output stream.
write(byte[], int, int) - Method in class com.linkedin.alpini.io.MeteredOutputStream
Writes len bytes from the specified byte array starting at offset off to this output stream.
write(byte[], int, int) - Method in class com.linkedin.alpini.io.NullOutputStream
 
write(byte[], int, int) - Method in class com.linkedin.alpini.io.PigzDeflateCompressor
 
write(byte[], int, int) - Method in class com.linkedin.alpini.io.PigzOutputStream.Compressor
 
write(byte[], int, int) - Method in class com.linkedin.alpini.io.PigzOutputStream
Writes len bytes from the specified byte array starting at offset off to this output stream.
write(byte[], int, int) - Method in class com.linkedin.venice.compression.ReusableGzipOutputStream
Writes array of bytes to the compressed output stream.
write(int) - Method in class com.linkedin.alpini.io.CompressOutputStream
Writes the specified byte to this output stream.
write(int) - Method in class com.linkedin.alpini.io.MeteredOutputStream
Writes the specified byte to this output stream.
write(int) - Method in class com.linkedin.alpini.io.NullOutputStream
 
write(int) - Method in class com.linkedin.alpini.io.PigzOutputStream
Writes the specified byte to this output stream.
write(ByteBuf) - Method in class com.linkedin.venice.router.streaming.VeniceChunkedResponse
 
write(ByteBuf, CompressionStrategy) - Method in class com.linkedin.venice.router.streaming.VeniceChunkedResponse
This function is used to send a data chunk to Venice Client.
write(ByteBuf, CompressionStrategy, StreamingCallback<Long>) - Method in class com.linkedin.venice.router.streaming.VeniceChunkedResponse
This function is used to send a data chunk to Venice Client, and when it is completed, 'callback' will be invoked.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.ElideDuplicateHeadersHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.HeaderStamp
Calls ChannelOutboundInvoker.write(Object, ChannelPromise) to forward to the next ChannelOutboundHandler in the ChannelPipeline.
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.Http2PingSendHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.HttpByteBufContentChunker
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.HttpMultiPartContentEncoder
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.HttpServerConcurrencyObserver
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.OutboundByteBufAggregator
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.http2.CompactHeaderHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.alpini.netty4.ssl.FusedSslHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.venice.listener.OutboundHttpWrapperHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.venice.listener.StatsHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class com.linkedin.venice.router.streaming.VeniceChunkedWriteHandler
 
write(ChannelHandlerContext, Object, ChannelPromise) - Method in class io.netty.handler.codec.EspressoMessageToMessageEncoder
 
write(DataOutput) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
 
write(ByteBuffer) - Method in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
 
write(List<PubSubMessage<KafkaKey, KafkaMessageEnvelope, Long>>) - Method in class com.linkedin.davinci.kafka.consumer.StorePartitionDataReceiver
 
write(K, Encoder) - Method in class com.linkedin.venice.serializer.AvroSerializer
 
write(MESSAGE) - Method in interface com.linkedin.davinci.ingestion.consumption.ConsumedDataReceiver
This method accepts data consumed from a queue and it should be non-blocking.
write(Schema, Object, Encoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumWriter
Deprecated.
 
write(Record<GenericObject>) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSink
 
Write - com.linkedin.venice.authorization.Method
 
WRITE_ACL_FAILED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
WRITE_ACL_FAILURE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
 
WRITE_COMPUTATION_ENABLED - com.linkedin.venice.Arg
 
WRITE_COMPUTATION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
WRITE_COMPUTE_DESERIALIZATION_FAILURE - com.linkedin.venice.stats.StatsErrorCode
This is bubbled up when write compute adapter fails to get the current value from the storage engine.
WRITE_COMPUTE_OPERATION_FAILURE - Static variable in class com.linkedin.davinci.stats.IngestionStats
 
WRITE_COMPUTE_RECORD_SCHEMA_SUFFIX - Static variable in class com.linkedin.venice.schema.writecompute.WriteComputeConstants
 
WRITE_COMPUTE_STORE - com.linkedin.venice.pushmonitor.PushMonitorType
 
WRITE_COMPUTE_UPDATE_FAILURE - com.linkedin.venice.stats.StatsErrorCode
This is bubbled up when write compute adapter fails to perform update operations on top of the current value.
WRITE_OPERATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
 
WRITE_SYSTEM_STORE - com.linkedin.venice.authorization.Method
 
WRITEABILITY - com.linkedin.venice.Arg
 
writeAclAuthorizationFailureCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
writeAlternateSimpleAvroFileWithStringToStringSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeAndFlushResponse(ChannelHandlerContext, FullHttpResponse) - Method in class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
 
writeAndRemoveAll(ChannelHandlerContext) - Method in class io.netty.channel.AbstractCoalescingBufferQueue10294
Writes all remaining elements in this queue.
writeAvroFileWithManyFloatsAndCustomTotalSize(File, int, int, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeBatchData(VersionCreationResponse, String, String, Stream<Map.Entry>, int, CompressionStrategy, Function<String, ByteBuffer>, PubSubProducerAdapterFactory, Map<String, String>) - Static method in class com.linkedin.venice.utils.TestUtils
 
writeBatchData(VersionCreationResponse, String, String, Stream<Map.Entry>, int, PubSubProducerAdapterFactory, Map<String, String>) - Static method in class com.linkedin.venice.utils.TestUtils
 
writeBoolean(byte[], Boolean, int) - Static method in class com.linkedin.venice.utils.ByteUtils
Write a boolean to the byte array starting at the given offset
writeBytes(byte[], int, int) - Method in class org.apache.avro.io.ByteBufferToHexFormatJsonEncoder
 
writeChunkedContent(ChannelHandlerContext, Promise<LastHttpContent>) - Method in interface com.linkedin.alpini.netty4.misc.ChunkedHttpResponse
 
writeChunkedContent(ChannelHandlerContext, Promise<LastHttpContent>) - Method in class com.linkedin.alpini.netty4.misc.DefaultFileChannelHttpResponse
 
writeComplexVsonFile(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeComputationEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
Whether write-path computation feature is enabled for this store
writeComputationEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
writeComputationEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
Whether or not write-path computation feature is enabled for this store.
WriteComputeConstants - Class in com.linkedin.venice.schema.writecompute
This utility class contains all String literal constants used in write compute.
writeComputeFailureCode - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
 
WriteComputeHandler - Interface in com.linkedin.venice.schema.writecompute
This interface provides methods to execute write-compute operation a value
WriteComputeHandlerV1 - Class in com.linkedin.venice.schema.writecompute
Write compute V1 handles value records that do not have replication metadata.
WriteComputeHandlerV1() - Constructor for class com.linkedin.venice.schema.writecompute.WriteComputeHandlerV1
 
WriteComputeHandlerV2 - Class in com.linkedin.davinci.schema.writecompute
Write compute V2 handles value records with replication metadata.
WriteComputeOperation - Enum in com.linkedin.venice.schema.writecompute
This enum describe the possible write compute operations Venice supports.
WriteComputeProcessor - Class in com.linkedin.davinci.schema.writecompute
This class is able to read write-computed value and apply it to original value.
WriteComputeProcessor(MergeRecordHelper) - Constructor for class com.linkedin.davinci.schema.writecompute.WriteComputeProcessor
 
WriteComputeSchemaConverter - Class in com.linkedin.venice.schema.writecompute
This class converts a Avro Schema.Type.RECORD schema to its write compute schema.
WriteComputeSchemaValidator - Class in com.linkedin.davinci.schema.writecompute
validate if a write-compute schema can be pair with value schema
WriteComputeSchemaValidator.InvalidWriteComputeException - Exception in com.linkedin.davinci.schema.writecompute
 
writeEmptyAvroFile(File, String, Schema) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeEmptyAvroFile(File, Schema) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeEndOfPush(Admin) - Method in class com.linkedin.venice.controller.server.CreateVersion
 
writeEndOfPush(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
 
writeEndOfPush(String, String, int, boolean) - Method in interface com.linkedin.venice.controller.Admin
 
writeEndOfPush(String, String, int, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
Create a local Venice writer based on store version info and, for each partition, use the writer to send END_OF_PUSH and END_OF_SEGMENT control messages to Kafka.
writeEndOfPush(String, String, int, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
 
writeETLFileWithUnionWithNullSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeETLFileWithUnionWithoutNullSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeETLFileWithUserSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeETLFileWithUserSchemaAndNullDefaultValue(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeExternal(ObjectOutput) - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.Count
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.Delete
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.GUID
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.Put
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.Update
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.metadata.response.VersionProperties
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.participant.protocol.KillPushJob
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.pushstatus.PushStatusKey
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.pushstatus.PushStatusValue
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.storage.protocol.ChunkId
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
 
writeExternal(ObjectOutput) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
 
writeFixed(byte[], int, int) - Method in class org.apache.avro.io.ByteBufferToHexFormatJsonEncoder
 
writeFixed(Schema, Object, Encoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumWriter
Deprecated.
In Vson-Avro conversion, Fixed type is specialized for representing 'single byte' or 'short'.
writeHeader() - Method in class com.linkedin.venice.compression.ReusableGzipOutputStream
 
writeHeartbeat(String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
writeHeartbeat(String, long) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
writeHeartbeat(String, long) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
 
writeInt(byte[], int, int) - Static method in class com.linkedin.venice.utils.ByteUtils
Write an int to the byte array starting at the given offset
writeInUseValueSchema(String, int, int) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
 
writeInvalidAvroFile(File, String) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeLong(byte[], long, int) - Static method in class com.linkedin.venice.utils.ByteUtils
Write a long to the byte array starting at the given offset
writeMap(Schema, Object, Encoder) - Method in class com.linkedin.davinci.serializer.avro.MapOrderPreservingGenericDatumWriter
 
writeMap(Schema, Object, Encoder) - Method in class com.linkedin.davinci.serializer.avro.MapOrderPreservingSpecificDatumWriter
 
writeMap(Schema, Object, Encoder) - Method in class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
 
writeMap(Schema, Object, Encoder) - Method in class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
 
writeMapWithDeterministicOrder(Schema, Object, Encoder) - Method in interface org.apache.avro.generic.DeterministicMapOrderDatumWriter
 
writeMultiLevelVsonFile(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeMultiLevelVsonFile2(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeOnly - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
 
writeOptions - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
Here RocksDB disables WAL, but relies on the 'flush', which will be invoked through RocksDBStoragePartition.sync() to avoid data loss during recovery.
WritePathLatencySensor - Class in com.linkedin.davinci.stats
This class serves as a latency sensor for write path that contains two types of stats: Avg and Max.
WritePathLatencySensor(MetricsRepository, MetricConfig, String) - Constructor for class com.linkedin.davinci.stats.WritePathLatencySensor
 
writePushStatus(String, int, int, ExecutionStatus, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
writePushStatus(String, int, int, ExecutionStatus, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
 
writer - Variable in class com.linkedin.venice.serializer.SerializerDeserializerFactory.SchemaPairAndClassContainer
 
WriterChunkingHelper - Class in com.linkedin.venice.writer
This class is a helper class that contains writer side chunking logics.
WriterChunkingHelper() - Constructor for class com.linkedin.venice.writer.WriterChunkingHelper
 
writeReadyToServerStoreReplicas(String, String, int, int, Collection<Instance>) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
This function is used to produce a snapshot for replica statuses.
writeRecord(Schema, Object, Encoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumWriter
Deprecated.
 
writeResponse(GrpcRequestContext) - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
 
writerSchemaId() - Method in class com.linkedin.davinci.store.record.ByteBufferValueRecord
 
writeSchemaWithUnknownFieldIntoAvroFile(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeShort(byte[], short, int) - Static method in class com.linkedin.venice.utils.ByteUtils
Write a short to the byte array starting at the given offset
writeSimpleAvroFileForValidateSchemaAndBuildDictMapperOutput(File, String, long, ByteBuffer, Schema) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithASchemaWithAWrongDefaultValue(File, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithCustomSize(File, int, int, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithDuplicateKey(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithIntToStringSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithString2StringSchema3(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
This file add some new value in TestWriteUtils.writeSimpleAvroFileWithStringToStringSchema(File) It's designed to test incremental push
writeSimpleAvroFileWithStringToPartialUpdateOpRecordSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithStringToRecordSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithStringToStringSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithStringToStringSchema(File, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithStringToStringSchema(File, int, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithStringToStringSchema(File, int, String) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithStringToStringSchema2(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
This file overrides half of the value in TestWriteUtils.writeSimpleAvroFileWithStringToStringSchema(File) and add some new values.
writeSimpleAvroFileWithStringToStringWithExtraSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleAvroFileWithStringToV3Schema(File, int, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleVsonFile(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeSimpleVsonFileWithUserSchema(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 
writeStoreClusterConfig(StoreConfig) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
Write StoreConfig equivalent to the meta system store.
writeStoreKeySchemas(String, Collection<SchemaEntry>) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
 
writeStoreProperties(String, Store) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
This function should be invoked for any store metadata change.
writeStoreValueSchemas(String, Collection<SchemaEntry>) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
This function should be invoked for any value schema changes, and the {@param valueSchemas} should contain all the value schemas since this operation will be a full PUT.
writeString(String) - Method in class org.apache.avro.io.ByteBufferToHexFormatJsonEncoder
Detect whether there is any non-ASCII character; if so, transfer the entire string into hexadecimal string.
writeTimedOut(ChannelHandlerContext) - Method in class io.netty.handler.timeout.ForceCloseOnWriteTimeoutHandler
 
writeTimeoutSeconds(int) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
 
writeTimeoutSeconds(int) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
 
writeTo(CodedOutputStream) - Method in class com.linkedin.venice.protocols.VeniceClientRequest
 
writeTo(CodedOutputStream) - Method in class com.linkedin.venice.protocols.VeniceServerResponse
 
writeToTempFile(byte[]) - Method in class com.linkedin.venice.hadoop.ssl.TempFileSSLConfigurator
 
writeUnion(Schema, Object, Encoder) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumWriter
Deprecated.
This method is kinda hacking.
writeVsonByteAndShort(File) - Static method in class com.linkedin.venice.utils.TestWriteUtils
 

X

X_CLUSTER_NAME - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_DEFLATE - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
X_ERROR_CAUSE_CLASS - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_ERROR_CAUSE_MESSAGE - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_ERROR_CLASS - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_ERROR_IN_RESPONSE - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_ERROR_MESSAGE - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_GZIP - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
X_METRICS - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_MULTIPART_CONTENT_STATUS - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_PARTITION - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_REQUEST_ID - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_RETURN_METRICS - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_SERVED_BY - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 
X_SNAPPY - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
X_SNAPPY_ENCODING - Static variable in class com.linkedin.alpini.netty4.compression.CompressionUtils
 
X_STACKTRACE - Static variable in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
 
X_USE_RESPONSE_BOUNDARY - Static variable in enum com.linkedin.alpini.base.misc.HeaderNames
 

Z

ZeroCopyByteArrayOutputStream - Class in com.linkedin.venice.io
 
ZeroCopyByteArrayOutputStream(int) - Constructor for class com.linkedin.venice.io.ZeroCopyByteArrayOutputStream
 
ZeroInputStream - Class in com.linkedin.alpini.io
A simple @{link InputStream} implementation which is equivalent to /dev/zero by acting as a source for a stream of NUL bytes.
ZeroInputStream(long) - Constructor for class com.linkedin.alpini.io.ZeroInputStream
 
ZK_SSL_CONFIG_FILE - com.linkedin.venice.Arg
 
ZkAdminTopicMetadataAccessor - Class in com.linkedin.venice.controller
 
ZkAdminTopicMetadataAccessor(ZkClient, HelixAdapterSerializer) - Constructor for class com.linkedin.venice.controller.ZkAdminTopicMetadataAccessor
 
ZkAllowlistAccessor - Class in com.linkedin.venice.helix
Class used to access to the allowlist stored in ZK.
ZkAllowlistAccessor(String) - Constructor for class com.linkedin.venice.helix.ZkAllowlistAccessor
 
ZkAllowlistAccessor(ZkClient, HelixAdapterSerializer) - Constructor for class com.linkedin.venice.helix.ZkAllowlistAccessor
 
zkClient - Variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
ZkClientFactory - Class in com.linkedin.venice.helix
 
ZkClientFactory() - Constructor for class com.linkedin.venice.helix.ZkClientFactory
 
ZkClientStatusStats - Class in com.linkedin.venice.stats
The stats keep track of ZK Client status changes.
ZkClientStatusStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.ZkClientStatusStats
 
ZkDataAccessException - Exception in com.linkedin.venice.exceptions
 
ZkDataAccessException(String, String, int) - Constructor for exception com.linkedin.venice.exceptions.ZkDataAccessException
 
zkDataAccessor - Variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
 
zkDataAccessor - Variable in class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
 
ZkExecutionIdAccessor - Class in com.linkedin.venice.controller
 
ZkExecutionIdAccessor(ZkClient, HelixAdapterSerializer) - Constructor for class com.linkedin.venice.controller.ZkExecutionIdAccessor
 
ZkHelixAdminClient - Class in com.linkedin.venice.controller
The purpose of this class is to abstract Helix operations out of the VeniceHelixAdmin and eventually rename it to VeniceAdmin.
ZkHelixAdminClient(VeniceControllerMultiClusterConfig, MetricsRepository) - Constructor for class com.linkedin.venice.controller.ZkHelixAdminClient
 
ZkRoutersClusterManager - Class in com.linkedin.venice.helix
Manage live routers through Zookeeper.
ZkRoutersClusterManager(ZkClient, HelixAdapterSerializer, String, int, long) - Constructor for class com.linkedin.venice.helix.ZkRoutersClusterManager
 
ZKStore - Class in com.linkedin.venice.meta
Class defines the store of Venice.
ZKStore(Store) - Constructor for class com.linkedin.venice.meta.ZKStore
 
ZKStore(StoreProperties) - Constructor for class com.linkedin.venice.meta.ZKStore
 
ZKStore(String, String, long, PersistenceType, RoutingStrategy, ReadStrategy, OfflinePushStrategy, int) - Constructor for class com.linkedin.venice.meta.ZKStore
 
ZKStore(String, String, long, PersistenceType, RoutingStrategy, ReadStrategy, OfflinePushStrategy, int, long, long, HybridStoreConfig, PartitionerConfig, int) - Constructor for class com.linkedin.venice.meta.ZKStore
 
ZkStoreConfigAccessor - Class in com.linkedin.venice.helix
The class is used to access the store configs in Zookeeper.
ZkStoreConfigAccessor(ZkClient, HelixAdapterSerializer, Optional<MetaStoreWriter>) - Constructor for class com.linkedin.venice.helix.ZkStoreConfigAccessor
 
ZONE_FIELD_NAME_IN_DOMAIN - Static variable in class com.linkedin.venice.helix.HelixInstanceConfigRepository
 
ZOOKEEPER_ADDRESS - Static variable in class com.linkedin.venice.ConfigKeys
 
ZSTD - com.linkedin.venice.compression.CompressionStrategy
Deprecated.
ZSTD_COMPRESSION_LEVEL - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Config to control the Compression Level for ZSTD Dictionary Compression.
ZSTD_DICTIONARY_CREATION_FAILED - com.linkedin.venice.hadoop.VenicePushJob.PushJobCheckpoints
 
ZSTD_DICTIONARY_CREATION_REQUIRED - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
Configs to pass to AbstractVeniceMapper based on the input configs and Dictionary training status
ZSTD_DICTIONARY_CREATION_SUCCESS - Static variable in class com.linkedin.venice.hadoop.VenicePushJobConstants
 
ZSTD_WITH_DICT - com.linkedin.venice.compression.CompressionStrategy
 
zstdCompressedValueSizeCounter - Variable in class com.linkedin.venice.hadoop.spark.datawriter.task.DataWriterAccumulators
 
zstdDictionary - Variable in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
Zstd compression dictionary
ZstdWithDictCompressor - Class in com.linkedin.venice.compression
 
ZstdWithDictCompressor(byte[], int) - Constructor for class com.linkedin.venice.compression.ZstdWithDictCompressor
 

_

_activeStreamsCountHandler - Variable in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
_aggregateFlushProcessingTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
aggregate nanos of outbound flush before this handler
_aggregateReadProcessingTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
aggregate nanos of inbound channelRead after this handler
_aggregateWriteProcessingTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
aggregate nanos of outbound write before this handler
_allocationTotal - Variable in class com.linkedin.alpini.base.queuing.AbstractQOS
 
_channelGroup - Variable in class com.linkedin.alpini.netty4.pool.FastFixedChannelPool
 
_e - Variable in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
 
_entries - Variable in class com.linkedin.alpini.base.misc.ArrayMap
 
_http2SettingsFrameLogger - Variable in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
 
_immediateEventExecutor - Variable in class com.linkedin.alpini.netty4.pool.FastSimpleChannelPool
 
_log - Variable in class com.linkedin.alpini.base.queuing.AbstractQOS
 
_log - Variable in class com.linkedin.alpini.base.statistics.AbstractQuantileEstimation
 
_method - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
method of the request
_qosBasedAllocations - Variable in class com.linkedin.alpini.base.queuing.AbstractQOS
 
_requestContentReceivedTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when end of request content was received
_requestContentStartTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when start of request content was received
_requestHeaderReceivedTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time the request was received
_responseContentFlushTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when flush was called after response content end was written
_responseContentReadyTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when response content end was written
_responseContentStartTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when response content start was written
_responseContentWrittenTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when response was completely written to the OS
_responseFirstDataFlushTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when flush was called after response content start was written
_responseHeaderFlushTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when flush was called after response header was written
_responseHeaderReadyTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when response header was written
_responseLastFlushTime - Variable in class com.linkedin.alpini.netty4.handlers.HttpServerStatisticsHandler.Stats
nanos at time when last flush was seen by this request
_setByte(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setInt(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setIntLE(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setLong(int, long) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setLongLE(int, long) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setMedium(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setMediumLE(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setShort(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_setShortLE(int, int) - Method in class com.linkedin.alpini.base.safealloc.DerivedMutableByteBuf
 
_state - Variable in class com.linkedin.alpini.base.registry.ResourceRegistry
 
_stddev - Variable in class com.linkedin.alpini.base.statistics.LongStatsAggregator.LongData
 
_timeoutProcessor - Variable in class com.linkedin.alpini.router.ScatterGatherRequestHandler
 
_trailingHeaders - Variable in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
 
_trailingHeaders - Variable in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
 
_useQueueSizeForAcquiredChannelCount - Variable in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
_usingFastPool - Variable in class com.linkedin.alpini.netty4.pool.FixedChannelPoolFactory
 
_value - Variable in class com.linkedin.alpini.base.statistics.DoubleQuantileEstimation.Sample
 
_value - Variable in class com.linkedin.alpini.base.statistics.GenericQuantileEstimation.Sample
 
_value - Variable in class com.linkedin.alpini.base.statistics.LongQuantileEstimation.Sample
 
A B C D E F G H I J K L M N O P Q R S T U V W X Z _ 
All Classes All Packages