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
All Classes All Packages
A
- AA_OR_WC_LEADER_DEDICATED - com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategyType
- AA_OR_WRITE_COMPUTE - com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext.WorkloadType
- AA_WC_LEADER_POOL - com.linkedin.davinci.kafka.consumer.ConsumerPoolType
-
The following pool types are being used when the dedicated AA/WC leader consumer pool feature is enabled.
- AAOrWCLeaderConsumerPoolStrategy() - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.AAOrWCLeaderConsumerPoolStrategy
- 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, SchemaReader) - 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
-
Class for commonalities between
AbstractInputRecordProcessor
,AbstractPartitionWriter
,KafkaInputFormatCombiner
andValidateSchemaAndBuildDictMapper
. - 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(IngestionBackend, 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, VeniceControllerClusterConfig, 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
- AbstractReadResponse - Class in com.linkedin.venice.listener.response
-
This class is used to store common fields shared by various read responses.
- AbstractReadResponse() - Constructor for class com.linkedin.venice.listener.response.AbstractReadResponse
- AbstractReadResponseStats - Class in com.linkedin.venice.listener.response.stats
-
This abstract class is the container for response stats.
- AbstractReadResponseStats() - Constructor for class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- 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(IngestionBackend, 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
- AbstractStorageEngine.StoragePartitionAdjustmentTrigger - Enum in com.linkedin.davinci.store
- 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(double, boolean) - Method in interface com.linkedin.venice.utils.DoubleAndBooleanConsumer
- 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 - com.linkedin.venice.controller.ParentControllerRegionState
-
The region is active, so the parent controller in the region is serving requests
- ACTIVE_ACTIVE - com.linkedin.venice.meta.DataReplicationPolicy
-
Deprecated.
- 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 regions 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_CHECK_FAILURE_WARN_MESSAGE_PREFIX - Static variable in class com.linkedin.venice.controller.server.VeniceParentControllerRegionStateHandler
- 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_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(VeniceControllerClusterConfig) - 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(long) - Method in class com.linkedin.davinci.listener.response.NoOpReadResponseStats
- addDatabaseLookupLatency(long) - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
-
The implementer is responsible for doing the subtraction between the current time and the start time.
- addDatabaseLookupLatency(long) - Method in class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- 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
- addIngestionNotifier(VeniceNotifier) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
- addIngestionNotifier(VeniceNotifier) - Method in interface com.linkedin.davinci.ingestion.IngestionBackend
- 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
- addKeySize(int) - Method in class com.linkedin.davinci.listener.response.NoOpReadResponseStats
- addKeySize(int) - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
- addKeySize(int) - Method in class com.linkedin.venice.listener.response.stats.ComputeResponseStatsWithSizeProfiling
- addKeySize(int) - Method in class com.linkedin.venice.listener.response.stats.MultiGetResponseStatsWithSizeProfiling
- addKeySize(int) - Method in class com.linkedin.venice.listener.response.stats.MultiKeyResponseStats
- addKeySize(int) - Method in class com.linkedin.venice.listener.response.stats.SingleGetResponseStats
- 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.main.MainIngestionMonitorService
- addReadComputeDeserializationLatency(double) - Method in class com.linkedin.davinci.listener.response.NoOpReadResponseStats
- addReadComputeDeserializationLatency(double) - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
- addReadComputeDeserializationLatency(double) - Method in class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- addReadComputeDeserializationLatency(double) - Method in class com.linkedin.venice.listener.response.stats.ComputeResponseStats
- addReadComputeLatency(double) - Method in class com.linkedin.davinci.listener.response.NoOpReadResponseStats
- addReadComputeLatency(double) - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
- addReadComputeLatency(double) - Method in class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- addReadComputeLatency(double) - Method in class com.linkedin.venice.listener.response.stats.ComputeResponseStats
- addReadComputeOutputSize(int) - Method in class com.linkedin.davinci.listener.response.NoOpReadResponseStats
- addReadComputeOutputSize(int) - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
- addReadComputeOutputSize(int) - Method in class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- addReadComputeOutputSize(int) - Method in class com.linkedin.venice.listener.response.stats.ComputeResponseStats
- addReadComputeSerializationLatency(double) - Method in class com.linkedin.davinci.listener.response.NoOpReadResponseStats
- addReadComputeSerializationLatency(double) - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
- addReadComputeSerializationLatency(double) - Method in class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- addReadComputeSerializationLatency(double) - Method in class com.linkedin.venice.listener.response.stats.ComputeResponseStats
- 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 sendingREPLICATION_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.NoOpReadResponseStats
- addValueSize(int) - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
- addValueSize(int) - Method in class com.linkedin.venice.listener.response.stats.ComputeResponseStats
- addValueSize(int) - Method in class com.linkedin.venice.listener.response.stats.ComputeResponseStatsWithSizeProfiling
- addValueSize(int) - Method in class com.linkedin.venice.listener.response.stats.MultiGetResponseStatsWithSizeProfiling
- addValueSize(int) - Method in class com.linkedin.venice.listener.response.stats.MultiKeyResponseStats
- addValueSize(int) - Method in class com.linkedin.venice.listener.response.stats.SingleGetResponseStats
- 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>, Integer) - 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, int) - Method in interface com.linkedin.venice.controller.Admin
-
This method behaves differently in
VeniceHelixAdmin
andVeniceParentHelixAdmin
. - addVersionAndStartIngestion(String, String, String, int, int, Version.PushType, String, long, int, boolean, int) - 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, int) - 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, int) - 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
- AdHash - Class in com.linkedin.venice.kafka.validation.checksum
-
This class AdHash is used to keep track of the checksum of the data incrementally.
- AdHash() - Constructor for class com.linkedin.venice.kafka.validation.checksum.AdHash
- AdHash(byte[]) - Constructor for class com.linkedin.venice.kafka.validation.checksum.AdHash
- ADHASH - com.linkedin.venice.kafka.validation.checksum.CheckSumType
- adjustStoragePartition(int, AbstractStorageEngine.StoragePartitionAdjustmentTrigger, 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_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_METADATA - Static variable in class com.linkedin.venice.zk.VeniceZkPaths
- 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_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.VeniceControllerClusterConfig
- 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, VeniceControllerClusterConfig, 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 executeAdminOperation
s 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 oneKafkaConsumerService
. - AggKafkaConsumerService(PubSubConsumerAdapterFactory, TopicManagerContext.PubSubPropertiesSupplier, VeniceServerConfig, IngestionThrottler, 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 forServerHttpRequestStats
corresponding to the type of requests defined inRequestType
. - 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 forServerQuotaTokenBucketStats
. - AggServerQuotaTokenBucketStats(MetricsRepository, ReadQuotaEnforcementHandler) - Constructor for class com.linkedin.venice.stats.AggServerQuotaTokenBucketStats
- AggServerQuotaUsageStats - Class in com.linkedin.venice.stats
-
AggServerQuotaUsageStats
is the aggregate statistics forServerQuotaUsageStats
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.
- ALLOWED - com.linkedin.venice.listener.ReadQuotaEnforcementHandler.QuotaEnforcementResult
- 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 - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- amplificationFactor - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
- 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
- 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.
- areAllPartitionsOnSameTerminalStatus(ExecutionStatus) - Method in class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- 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 immutableCollection
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
backedMap
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.
- ASSEMBLED_RECORD_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.stats.HostLevelIngestionStats
- ASSEMBLED_RECORD_SIZE_RATIO - Static variable in class com.linkedin.davinci.stats.HostLevelIngestionStats
- ASSEMBLED_RMD_SIZE_IN_BYTES - Static variable in class com.linkedin.davinci.stats.HostLevelIngestionStats
- 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 whereAsyncFutureListener
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
- AsyncRetryingServiceDiscoveryAnnouncer - Class in com.linkedin.venice.servicediscovery
-
This class is responsible for announcing and de-announcing a
ServiceDiscoveryAnnouncer
to a Service Discovery system and taking care of failed registrations by retrying them asynchronously. - AsyncRetryingServiceDiscoveryAnnouncer(List<ServiceDiscoveryAnnouncer>, long) - Constructor for class com.linkedin.venice.servicediscovery.AsyncRetryingServiceDiscoveryAnnouncer
- 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 givenAttributeKey
. - attr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
-
Get the
Attribute
for the givenAttributeKey
. - attr(AttributeKey<T>) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpResponse
-
Get the
Attribute
for the givenAttributeKey
. - 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 permissionPermission
to principalsPrincipal
when performingMethod
. - 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 invokeAbstractAvroStoreClient
to send the 'compute' request to backend. - AvroComputeRequestBuilderV3(AvroGenericReadComputeStoreClient, SchemaReader) - Constructor for class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
- AvroComputeRequestBuilderV4<K> - Class in com.linkedin.venice.client.store
- AvroComputeRequestBuilderV4(AvroGenericReadComputeStoreClient, SchemaReader) - 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 - com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext.VersionRole
- 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 theBackupVersionOptimizationService
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 - com.linkedin.venice.listener.ReadQuotaEnforcementHandler.QuotaEnforcementResult
- BAD_REQUEST - Static variable in class com.linkedin.venice.response.VeniceReadResponseStatus
- 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
- BASE_PATH - com.linkedin.venice.Arg
- 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
andBasicHttpResponseDecoder
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)
, andmaxChunkSize (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)
, andmaxChunkSize (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)
, andmaxChunkSize (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
ByteBuf
s intoHttpResponse
s andHttpContent
s. - BasicHttpResponseDecoder() - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpResponseDecoder
-
Creates a new instance with the default
maxInitialLineLength (4096)
,maxHeaderSize (8192)
, andmaxChunkSize (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)
, andmaxChunkSize (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
- batchPushEndSignalSent() - Method in class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- batchPushStartSignalSent() - Method in class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- 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
- BEGIN_BATCH_PUSH - com.linkedin.davinci.store.AbstractStorageEngine.StoragePartitionAdjustmentTrigger
- 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_COMPLETED - Static variable in class com.linkedin.venice.blobtransfer.BlobTransferUtils
- BLOB_TRANSFER_ENABLED - com.linkedin.venice.Arg
- BLOB_TRANSFER_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- BLOB_TRANSFER_MANAGER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_STATUS - Static variable in class com.linkedin.venice.blobtransfer.BlobTransferUtils
- BlobFinder - Interface in com.linkedin.venice.blobtransfer
- BlobPeersDiscoveryResponse - Class in com.linkedin.venice.blobtransfer
- BlobPeersDiscoveryResponse() - Constructor for class com.linkedin.venice.blobtransfer.BlobPeersDiscoveryResponse
- BlobSnapshotManager - Class in com.linkedin.davinci.blobtransfer
-
This class will take and return a snapshot of a hybrid store, if someone is using a snapshot then it will return the snapshot that person is using, otherwise, it will return the last snapshot taken if it is not stale If the snapshot is stale and no one is using it, it will update the snapshot and return the new one
- BlobSnapshotManager(String, long, ReadOnlyStoreRepository) - Constructor for class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Constructor for the BlobSnapshotManager
- 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
- BlobTransferManager<T> - Interface in com.linkedin.venice.blobtransfer
-
A BlobTransferManager is responsible for transferring blobs between two entities, either that Peer to Peer or node to a blob store and vice versa.
- BlobTransferNettyChannelInitializer - Class in com.linkedin.venice.blobtransfer.server
- BlobTransferNettyChannelInitializer(String) - Constructor for class com.linkedin.venice.blobtransfer.server.BlobTransferNettyChannelInitializer
- BlobTransferPayload - Class in com.linkedin.venice.blobtransfer
-
POJO to hold the payload for blob transfer related informartion
- BlobTransferPayload(String, String, int, int) - Constructor for class com.linkedin.venice.blobtransfer.BlobTransferPayload
- BlobTransferUtil - Class in com.linkedin.venice.blobtransfer
- BlobTransferUtil() - Constructor for class com.linkedin.venice.blobtransfer.BlobTransferUtil
- BlobTransferUtils - Class in com.linkedin.venice.blobtransfer
- BlobTransferUtils() - Constructor for class com.linkedin.venice.blobtransfer.BlobTransferUtils
- 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.
- BlockingDaVinciRecordTransformer<K,V,O> - Class in com.linkedin.davinci.client
-
This is an implementation of
DaVinciRecordTransformer
that implements blocking. - BlockingDaVinciRecordTransformer(DaVinciRecordTransformer) - Constructor for class com.linkedin.davinci.client.BlockingDaVinciRecordTransformer
- 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 ofcharset
. - 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 ofcharset
. - 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 ofcharset
. - 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 ofcharset
. - 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 newByteBuffer
, 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
- calculateAssembledRecordSizeRatio(long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- calculateAssembledRecordSizeRatio(long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- 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 returnsnull
. - 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
- cancel(boolean) - Method in class com.linkedin.davinci.utils.LockAssistedCompletableFuture
- 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
- 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_ACTIVATED - Static variable in class com.linkedin.venice.listener.ServerConnectionStatsHandler
- 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 nextChannelInboundHandler
in theChannelPipeline
. - channelActive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.Log4J2LoggingHandler
- channelActive(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ReverseHandler
- channelActive(ChannelHandlerContext) - Method in class com.linkedin.venice.blobtransfer.server.P2PFileTransferServerHandler
- channelActive(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.ServerConnectionStatsHandler
- 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 nextChannelInboundHandler
in theChannelPipeline
. - 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.blobtransfer.client.P2PFileTransferClientHandler
- channelInactive(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.ServerConnectionStatsHandler
- 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 aChannel
once it was registered to itsEventLoop
. - 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 theChannelPoolManager
. - 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.blobtransfer.server.P2PFileTransferServerHandler
-
This method is called with the request that is received from the client.
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.venice.listener.RouterRequestHttpHandler
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class com.linkedin.venice.blobtransfer.client.P2PFileTransferClientHandler
- 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
- 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
- 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_DATABASE_INTEGRITY - com.linkedin.davinci.store.AbstractStorageEngine.StoragePartitionAdjustmentTrigger
- 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
- 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
- checkpointingSupportedCheckSumTypes() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- 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
- 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.
- CHUNK_LENGTH - Static variable in class com.linkedin.venice.utils.ChunkingTestUtils
- 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 callChunkAwareCallback.setChunkingInfo(byte[], ByteBuffer[], ChunkedValueManifest, ByteBuffer[], ChunkedValueManifest, ChunkedValueManifest, ChunkedValueManifest)
whenever processing aMessageType.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 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).
- ChunkingTestUtils - Class in com.linkedin.venice.utils
- 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
- clearIngestionKillMessageAndVerify(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Clear KILL messages from a participant system store.
- 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 accessStoreIngestionTask.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.IngestionThrottler
- 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 interface com.linkedin.venice.blobtransfer.BlobTransferManager
-
Close the blob transfer manager and related resources
- close() - Method in class com.linkedin.venice.blobtransfer.client.NettyFileTransferClient
- close() - Method in class com.linkedin.venice.blobtransfer.DaVinciBlobFinder
- close() - Method in class com.linkedin.venice.blobtransfer.NettyP2PBlobTransferManager
- close() - Method in class com.linkedin.venice.blobtransfer.ServerBlobFinder
- 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
- 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.ParticipantStoreClientsManager
- 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.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(long) - Method in interface com.linkedin.alpini.base.monitoring.CallCompletion
- close(long) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
- close(long) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
- close(long) - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
- close(long) - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
- 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_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
forAutoCloseable
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_CONFIG - Static variable in class com.linkedin.venice.zk.VeniceZkPaths
- 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_LIST - com.linkedin.venice.Arg
- 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
- CLUSTER_ZK_PATHS - Static variable in class com.linkedin.venice.zk.VeniceZkPaths
- 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.blobtransfer - package com.linkedin.davinci.blobtransfer
- 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.blobtransfer - package com.linkedin.venice.blobtransfer
- com.linkedin.venice.blobtransfer.client - package com.linkedin.venice.blobtransfer.client
- com.linkedin.venice.blobtransfer.server - package com.linkedin.venice.blobtransfer.server
- 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.listener.response.stats - package com.linkedin.venice.listener.response.stats
- 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.pu