Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AA_OR_WC_LEADER_DEDICATED - Enum constant in enum class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategyType
- AA_OR_WRITE_COMPUTE - Enum constant in enum class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext.WorkloadType
- AA_WC_LEADER_POOL - Enum constant in enum class 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
- aaWCIngestionStorageLookupThreadPool - Variable in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- ABORT - Enum constant in enum class com.linkedin.venice.hooks.StoreLifecycleEventOutcome
- ABORT - Enum constant in enum class com.linkedin.venice.hooks.StoreVersionLifecycleEventOutcome
-
Fail the push job associated with this hook.
- ABORT_MIGRATION - Enum constant in enum class com.linkedin.venice.Command
- ABORT_MIGRATION - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- ABORT_MIGRATION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- aborted(boolean) - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Builder
- ABORTED_RETRY_COUNT - Enum constant in enum class com.linkedin.venice.router.stats.RouterMetricEntity
-
Count of aborted retry requests
- 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, 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
- AbstractDataWriterSparkJob - Class in com.linkedin.venice.spark.datawriter.jobs
-
The implementation of
DataWriterComputeJob
for Spark engine. - AbstractDataWriterSparkJob() - Constructor for class com.linkedin.venice.spark.datawriter.jobs.AbstractDataWriterSparkJob
- AbstractDataWriterTask - Class in com.linkedin.venice.hadoop.task.datawriter
-
Class for commonalities between
AbstractInputRecordProcessor
,AbstractPartitionWriter
, andKafkaInputFormatCombiner
. - 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.ChildWriterProducerCallback - Class in com.linkedin.venice.hadoop.task.datawriter
- 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, VeniceWriterFactory) - Constructor for class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- 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.
- 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
- AbstractStorageIterator - Class in com.linkedin.davinci.store
- AbstractStorageIterator() - Constructor for class com.linkedin.davinci.store.AbstractStorageIterator
- 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
- AbstractStoreAclHandler<REQUEST_TYPE> - Class in com.linkedin.venice.acl.handler
-
Store-level access control handler, which is being used by both Router and Server.
- AbstractStoreAclHandler(IdentityParser, DynamicAccessController, ReadOnlyStoreRepository, int) - Constructor for class com.linkedin.venice.acl.handler.AbstractStoreAclHandler
- AbstractStoreAclHandler(IdentityParser, DynamicAccessController, ReadOnlyStoreRepository, int, Time) - Constructor for class com.linkedin.venice.acl.handler.AbstractStoreAclHandler
- 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(String, MetricsRepository) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStats
- AbstractVeniceAggStats(String, MetricsRepository, StatsSupplier<T>, boolean) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStats
-
clusterName is used to create per cluster aggregate stats and
VeniceMetricsDimensions
If perClusterAggregate is true, it will create per cluster aggregates with storeName as "total." - AbstractVeniceAggStoreStats<T extends AbstractVeniceStats> - Class in com.linkedin.venice.stats
-
This class is an aggregate place that keeps stats objects for multiple stores.
- AbstractVeniceAggStoreStats(String, MetricsRepository, ReadOnlyStoreRepository, boolean) - Constructor for class com.linkedin.venice.stats.AbstractVeniceAggStoreStats
- AbstractVeniceAggStoreStats(String, MetricsRepository, StatsSupplier<T>, ReadOnlyStoreRepository, boolean, 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 Class 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, boolean) - Method in interface com.linkedin.venice.utils.DoubleAndBooleanConsumer
- accept(K, V, S) - Method in interface com.linkedin.venice.utils.TriConsumer
-
Performs this operation on the given arguments.
- 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
- ACCEPTED - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- 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
- 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
- acceptInboundMessage(Object) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
- acceptInboundMessage(Object) - Method in class com.linkedin.davinci.blobtransfer.client.MetadataAggregator
- ACCESS_CONTROL - Enum constant in enum class 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).
- ACCESSPERMISSION_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- ACCESSPERMISSIONS_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- ACCESSPERMISSIONS_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
- AccessResult - Enum Class in com.linkedin.venice.acl.handler
- accessResultToGrpcStatus(AccessResult) - Static method in class com.linkedin.venice.grpc.GrpcUtils
- 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_IN_MEMORY_CACHE_TTL_MS - Static variable in class com.linkedin.venice.ConfigKeys
- ACL_PERMS - Enum constant in enum class 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
- 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 - Enum constant in enum class com.linkedin.venice.controller.ParentControllerRegionState
-
The region is active, so the parent controller in the region is serving requests
- ACTIVE_ACTIVE - Enum constant in enum class com.linkedin.venice.meta.DataReplicationPolicy
-
Deprecated.
- ACTIVE_ACTIVE_NOT_ENABLED - Enum constant in enum class 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 - Enum constant in enum class 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, DefaultPubSubMessage, 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(StorageService, StoreIngestionTaskFactory.Builder, Store, Version, Properties, BooleanSupplier, VeniceStoreVersionConfig, int, boolean, Optional<ObjectCacheBackend>, DaVinciRecordTransformerConfig, Lazy<ZKHelixAdmin>) - Constructor for class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- 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
- AdaptiveThrottlerSignalService - Class in com.linkedin.davinci.kafka.consumer
-
This class contains service to periodically refresh all the signals for throttlers and update all registered throttler based on new signal values.
- AdaptiveThrottlerSignalService(VeniceServerConfig, MetricsRepository, HeartbeatMonitoringService) - Constructor for class com.linkedin.davinci.kafka.consumer.AdaptiveThrottlerSignalService
- AdaptiveThrottlingServiceStats - Class in com.linkedin.davinci.stats
- AdaptiveThrottlingServiceStats(MetricsRepository) - Constructor for class com.linkedin.davinci.stats.AdaptiveThrottlingServiceStats
- 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(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.venice.utils.collections.ArrayCollection
- add(E) - Method in class com.linkedin.venice.utils.SparseConcurrentList
- 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.venice.utils.collections.MemoryBoundBlockingQueue
- add(ImmutableMapEntry<K, V>) - Method in class com.linkedin.venice.utils.CollectionUtils.MapBuilder
- add(ImmutableMapEntry<K, V>...) - Method in class com.linkedin.venice.utils.CollectionUtils.MapBuilder
- ADD_DERIVED_SCHEMA - Enum constant in enum class com.linkedin.venice.Command
- ADD_DERIVED_SCHEMA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ADD_NULL_TO_UNION - Enum constant in enum class com.linkedin.venice.etl.ETLValueSchemaTransformation
- ADD_SCHEMA - Enum constant in enum class com.linkedin.venice.Command
- ADD_SCHEMA_TO_ZK - Enum constant in enum class com.linkedin.venice.Command
- ADD_TO_STORE_ACL - Enum constant in enum class com.linkedin.venice.Command
- ADD_VALUE_SCHEMA - Enum constant in enum class com.linkedin.venice.authorization.Method
- ADD_VALUE_SCHEMA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ADD_VERSION - Enum constant in enum class com.linkedin.venice.authorization.Method
- ADD_VERSION - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- ADD_VERSION - Enum constant in enum class 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.
- addAcl(String) - Method in class com.linkedin.venice.acl.NoOpDynamicAccessController
- 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.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.venice.utils.collections.MemoryBoundBlockingQueue
- addAll(Collection<? extends ImmutableMapEntry<K, V>>) - Method in class com.linkedin.venice.utils.CollectionUtils.MapBuilder
- addAll(Iterator<? extends ImmutableMapEntry<K, V>>) - Method in class com.linkedin.venice.utils.CollectionUtils.MapBuilder
- 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 into the 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.
- 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
- addIncPushVersionToPendingReportList(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- 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
- addKey(String, K, byte[], int) - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
- 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.
- addLiveInstanceChangeListener(LiveInstanceChangeListener) - Method in class com.linkedin.venice.helix.SafeHelixManager
- addLocalStorageEngine(StorageEngine) - Method in class com.linkedin.davinci.storage.StorageEngineRepository
- addMessageListener(MessageListener, String) - Method in class com.linkedin.venice.helix.SafeHelixManager
- addMessageToBuffer(K, V, int) - Method in class com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl.DaVinciRecordTransformerBootstrappingChangelogConsumer
- 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
- addNonAvailableReplicaPartition(int) - Method in class com.linkedin.venice.fastclient.RequestContext
- 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.
- addPreConnectCallback(PreConnectCallback) - Method in class com.linkedin.venice.helix.SafeHelixManager
- addPropertyDiff(String, String, String, String, String) - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
- addPubSubBrokerAddress(Properties, String) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- 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.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- 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
- addService(BindableService) - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig.Builder
- 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(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- addStoragePartition(int) - Method in interface com.linkedin.davinci.store.StorageEngine
- 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, int) - Method in class com.linkedin.venice.meta.AbstractStore
- addVersion(Version, boolean, int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- addVersion(Version, boolean, int) - 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, 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 function is only being used by store migration parent controllers, which write add version admin message.
- addVersionAndStartIngestion(String, String, String, int, int, Version.PushType, String, long, int, boolean, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- addVersionAndStartIngestion(String, String, String, int, int, Version.PushType, String, long, int, boolean, String, int, 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.
- addVersionAndTopicOnly(String, String, String, int, int, int, boolean, boolean, Version.PushType, String, String, Optional<String>, long, int, Optional<String>, boolean, String, int, 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.
- AddVersionLatencyStats - Class in com.linkedin.venice.controller.stats
-
This class is used to track the latency of various operations related to adding a version in Venice.
- AddVersionLatencyStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.AddVersionLatencyStats
- addVersionOnly(String, String, String, int, int, Version.PushType, String, long, int, 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
- 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 - Enum constant in enum class com.linkedin.venice.kafka.validation.checksum.CheckSumType
- adjustSeekCheckPointsBasedOnHeartbeats(Map<Integer, VeniceChangeCoordinate>, Map<Integer, Long>, PubSubConsumerAdapter, List<PubSubTopicPartition>) - Static method in class com.linkedin.davinci.consumer.VeniceAfterImageConsumerImpl
- adjustStoragePartition(int, StoragePartitionAdjustmentTrigger, StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Adjust the opened storage partition according to the provided storagePartitionConfig.
- adjustStoragePartition(int, StoragePartitionAdjustmentTrigger, StoragePartitionConfig) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- adjustStoragePartition(int, StoragePartitionAdjustmentTrigger, StoragePartitionConfig) - Method in interface com.linkedin.davinci.store.StorageEngine
-
Adjust the opened storage partition according to the provided storagePartitionConfig.
- ADLER32 - Enum constant in enum class 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 - Enum constant in enum class com.linkedin.venice.meta.QueryAction
- ADMIN - Enum constant in enum class com.linkedin.venice.pubsub.PubSubClientType
- 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 - Enum constant in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
-
Used to encode metadata changes about the system as a whole.
- ADMIN_OPERATION_PROTOCOL_VERSION - Enum constant in enum class com.linkedin.venice.Arg
- ADMIN_OPERATION_PROTOCOL_VERSION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- ADMIN_PORT - Static variable in class com.linkedin.venice.ConfigKeys
- ADMIN_SECURE_PORT - Static variable in class com.linkedin.venice.ConfigKeys
- ADMIN_TOOL - Enum constant in enum class com.linkedin.venice.acl.VeniceComponent
- ADMIN_TOPIC - Enum constant in enum class 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 class 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
- ADMINCOMMANDEXECUTIONID_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- ADMINCOMMANDEXECUTIONID_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- 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 Class in com.linkedin.venice.controllerapi
- AdminCommandExecutionStatusGrpcRequest - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- AdminCommandExecutionStatusGrpcRequest.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- AdminCommandExecutionStatusGrpcRequestOrBuilder - Interface in com.linkedin.venice.protocols.controller
- AdminCommandExecutionStatusGrpcResponse - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- AdminCommandExecutionStatusGrpcResponse.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- AdminCommandExecutionStatusGrpcResponseOrBuilder - Interface in com.linkedin.venice.protocols.controller
- 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, PubSubConsumerAdapterFactory, 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, 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. - AdminMessageConsumptionTimeoutException - Exception in com.linkedin.venice.exceptions
-
Used when there is a timeout from waiting for an admin message to be consumed
- AdminMessageConsumptionTimeoutException(String, Throwable) - Constructor for exception com.linkedin.venice.exceptions.AdminMessageConsumptionTimeoutException
- AdminMessageType - Enum Class 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
- ADMINOPERATIONPROTOCOLVERSION_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- ADMINOPERATIONPROTOCOLVERSION_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- AdminOperationProtocolVersionControllerResponse - Class in com.linkedin.venice.controllerapi
- AdminOperationProtocolVersionControllerResponse() - Constructor for class com.linkedin.venice.controllerapi.AdminOperationProtocolVersionControllerResponse
- 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, VeniceControllerRequestHandler) - 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
- AdminTopicGrpcMetadata - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- AdminTopicGrpcMetadata.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- AdminTopicGrpcMetadataOrBuilder - Interface in com.linkedin.venice.protocols.controller
- AdminTopicMetadataAccessor - Class in com.linkedin.venice.controller
- AdminTopicMetadataAccessor() - Constructor for class com.linkedin.venice.controller.AdminTopicMetadataAccessor
- AdminTopicMetadataGrpcRequest - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- AdminTopicMetadataGrpcRequest.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- AdminTopicMetadataGrpcRequestOrBuilder - Interface in com.linkedin.venice.protocols.controller
- AdminTopicMetadataGrpcResponse - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- AdminTopicMetadataGrpcResponse.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- AdminTopicMetadataGrpcResponseOrBuilder - Interface in com.linkedin.venice.protocols.controller
- 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 class 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(String, 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, StaleTopicChecker, 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 - Enum constant in enum class com.linkedin.venice.meta.DataReplicationPolicy
-
Deprecated.
- 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
- AGGREGATED_HEALTH_STATUS - Enum constant in enum class com.linkedin.venice.Command
- AGGREGATED_HEALTH_STATUS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- AggregatedHealthStatusRequest - Class in com.linkedin.venice.controllerapi
- AggregatedHealthStatusRequest(String, List<String>, List<String>) - Constructor for class com.linkedin.venice.controllerapi.AggregatedHealthStatusRequest
- AggregatedHeartbeatLagEntry - Class in com.linkedin.davinci.stats.ingestion.heartbeat
- AggregatedHeartbeatLagEntry(long, long) - Constructor for class com.linkedin.davinci.stats.ingestion.heartbeat.AggregatedHeartbeatLagEntry
- 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(String, MetricsRepository, Statistics) - Constructor for class com.linkedin.venice.stats.AggRocksDBStats
- AggRouterHttpRequestStats - Class in com.linkedin.venice.router.stats
- AggRouterHttpRequestStats(String, MetricsRepository, RequestType, boolean, ReadOnlyStoreRepository, boolean, Sensor) - Constructor for class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
- AggRouterHttpRequestStats(String, 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(String, MetricsRepository, RequestType, boolean, ReadOnlyStoreRepository, boolean, boolean) - Constructor for class com.linkedin.venice.stats.AggServerHttpRequestStats
- AggServerQuotaUsageStats - Class in com.linkedin.venice.stats
-
AggServerQuotaUsageStats
is the aggregate statistics forServerQuotaUsageStats
which measures requests and quota rejections of each store. - AggServerQuotaUsageStats(String, 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
- aggVersionedBlobTransferStats - Variable in class com.linkedin.davinci.blobtransfer.NettyP2PBlobTransferManager
- AggVersionedBlobTransferStats - Class in com.linkedin.davinci.stats
-
The store level stats for blob transfer
- AggVersionedBlobTransferStats(MetricsRepository, ReadOnlyStoreRepository, VeniceServerConfig) - Constructor for class com.linkedin.davinci.stats.AggVersionedBlobTransferStats
- AggVersionedDaVinciRecordTransformerStats - Class in com.linkedin.davinci.stats
-
The store level stats for
DaVinciRecordTransformer
- AggVersionedDaVinciRecordTransformerStats(MetricsRepository, ReadOnlyStoreRepository, VeniceServerConfig) - Constructor for class com.linkedin.davinci.stats.AggVersionedDaVinciRecordTransformerStats
- 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
- ALIVE - Enum constant in enum class com.linkedin.venice.pushstatushelper.PushStatusStoreReader.InstanceStatus
- ALL - Enum constant in enum class com.linkedin.venice.meta.VeniceUserStoreType
-
All user stores in Venice, excluding system stores.
- allAvroTypesExceptNullAndUnion() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- alloc() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- 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 - Enum constant in enum class 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.vpj.VenicePushJobConstants
- ALLOW_LIST_ADD_NODE - Enum constant in enum class com.linkedin.venice.Command
- ALLOW_LIST_ADD_NODE - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ALLOW_LIST_REMOVE_NODE - Enum constant in enum class com.linkedin.venice.Command
- ALLOW_LIST_REMOVE_NODE - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ALLOW_STORE_MIGRATION - Enum constant in enum class 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 - Enum constant in enum class com.linkedin.venice.listener.ReadQuotaEnforcementHandler.QuotaEnforcementResult
- ALLOWED_RETRY_COUNT - Enum constant in enum class com.linkedin.venice.router.stats.RouterMetricEntity
-
Count of allowed retry requests
- 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 - Enum constant in enum class com.linkedin.venice.utils.VeniceResourceCloseResult
- alreadySubscribedRealtimeTopicPartition(SharedKafkaConsumer, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.PartitionWiseKafkaConsumerService
- ALWAYS_ON_MULTI_THREADED_PIPELINE - Enum constant in enum class 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<T>...) - Static method in interface com.linkedin.venice.client.store.predicate.Predicate
- AndPredicate<T> - 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 - Enum constant in enum class com.linkedin.venice.meta.ReadStrategy
- anyOf(double...) - Static method in interface com.linkedin.venice.client.store.predicate.DoublePredicate
- anyOf(float...) - Static method in interface com.linkedin.venice.client.store.predicate.FloatPredicate
- anyOf(int...) - Static method in interface com.linkedin.venice.client.store.predicate.IntPredicate
- anyOf(long...) - Static method in interface com.linkedin.venice.client.store.predicate.LongPredicate
- anyOf(T...) - Static method in interface com.linkedin.venice.client.store.predicate.Predicate
- AnyOfPredicate<T> - Class in com.linkedin.venice.client.store.predicate
- APACHE_HTTP_ASYNC_CLIENT - Enum constant in enum class com.linkedin.venice.router.httpclient.StorageNodeClientType
-
Deprecated.
- APACHE_KAFKA_OFFSET_POSITION_TYPE_ID - Static variable in class com.linkedin.venice.pubsub.PubSubPositionTypeRegistry
- 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) - 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
-
Constructor for ApacheKafkaAdminAdapterFactory used mainly for reflective instantiation.
- ApacheKafkaAdminConfig - Class in com.linkedin.venice.pubsub.adapter.kafka.admin
- ApacheKafkaAdminConfig(PubSubAdminAdapterContext) - 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
-
Constructor for ApacheKafkaConsumerAdapterFactory used mainly for reflective instantiation.
- ApacheKafkaConsumerConfig - Class in com.linkedin.venice.pubsub.adapter.kafka.consumer
-
Configuration for Apache Kafka consumer.
- ApacheKafkaOffsetPosition - Class in com.linkedin.venice.pubsub.adapter.kafka.common
-
Offset position for Apache Kafka topics
- ApacheKafkaOffsetPosition(long) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPosition
- ApacheKafkaOffsetPosition(ByteBuffer) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPosition
- ApacheKafkaOffsetPositionFactory - Class in com.linkedin.venice.pubsub.adapter.kafka.common
-
A
PubSubPositionFactory
for creatingApacheKafkaOffsetPosition
instances. - ApacheKafkaOffsetPositionFactory(int) - Constructor for class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPositionFactory
- 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
-
Constructor for ApacheKafkaProducerAdapterFactory used for reflective instantiation.
- 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(PubSubProducerAdapterContext) - 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.logger.TestLogAppender
- 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 class 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 class com.linkedin.alpini.base.misc.ExceptionUtil
- appendStackTraceElement(StringBuilder, StackTraceElement) - Static method in enum class com.linkedin.alpini.base.misc.ExceptionUtil
-
Appends a StackTraceElement in the same way that StackTraceElement.toString() would except without creating intermediate String objects.
- 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(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(Integer, Schema, Schema, Schema, DaVinciRecordTransformerConfig) - Method in interface com.linkedin.davinci.client.DaVinciRecordTransformerFunctionalInterface
- apply(String) - Method in interface com.linkedin.venice.AdminTool.PrintFunction
- apply(String) - Method in class com.linkedin.venice.BackfillMinIsrTask
- apply(String) - Method in class com.linkedin.venice.SystemStorePushTask
- apply(String, String, D2ControllerClient, int) - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory.ViewClassGetter
- applyAdditionalWriterConfigs(Map<String, String>) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
- applyConfigBasedOnReplication(String, String, String, Lazy<Boolean>) - Method in class com.linkedin.venice.controller.server.CreateVersion
- applyFactoryModifiers(T, List<Function<T, T>>) - Static method in enum class 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
- 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
- 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 - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
Deprecated.
- areAllPartitionsOnSameTerminalStatus(ExecutionStatus, Optional<String>) - Method in class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- Arg - Enum Class in com.linkedin.venice
-
TODO: Merge this with
ControllerApiConstants
- array(P...) - Static method in class com.linkedin.alpini.base.misc.Pair
-
Return an array of Pair.
- ARRAY_BLOCKING_QUEUE - Enum constant in enum class com.linkedin.venice.utils.concurrent.BlockingQueueType
- 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<E>
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
- arrayNext() - Method in class org.apache.avro.io.ByteBufferOptimizedBinaryDecoder
- ArrayUtils - Class in com.linkedin.venice.utils
- asBroadcast() - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
- asCompletableFuture(Future<T>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
- 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
- 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
- assertCommandFailure(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 Class 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.
- 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.
- 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.
- attempts(int) - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Builder
- 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 - Enum constant in enum class 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
- 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 - Enum constant in enum class 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, AbstractAvroChunkingAdapter<V>, Runnable, Executor) - Constructor for class com.linkedin.davinci.client.AvroGenericDaVinciClient
- AvroGenericDaVinciClient(DaVinciConfig, ClientConfig, VeniceProperties, Optional<Set<String>>, ICProvider, Executor) - 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 Class 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 Class 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, Executor) - 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
- AvroSpecificStoreDeserializerCache(Schema, 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
- AvroToSQL - Class in com.linkedin.venice.sql
-
Utility intended to convert Avro -> SQL, including DDL and DML statements.
- AvroToSQL.UnsupportedTypeHandling - Enum Class in com.linkedin.venice.sql
- 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.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(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.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 interface com.linkedin.alpini.base.misc.Time.Awaitable
- await(Time.Awaitable, long, TimeUnit) - Static method in enum class com.linkedin.alpini.base.misc.Time
- await(CountDownLatch, long, TimeUnit) - Static method in enum class com.linkedin.alpini.base.misc.Time
- await(Condition, long, TimeUnit) - Static method in enum class 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
- 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.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(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.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.
B
- 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 - Enum constant in enum class com.linkedin.venice.Command
- BackfillMinIsrTask - Class in com.linkedin.venice
- BackfillMinIsrTask(Map<String, ControllerClient>, int, int) - Constructor for class com.linkedin.venice.BackfillMinIsrTask
- BACKUP - Enum constant in enum class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext.VersionRole
- BACKUP_FOLDER - Enum constant in enum class com.linkedin.venice.Arg
- BACKUP_STORE_METADATA_FROM_GRAVEYARD - Enum constant in enum class com.linkedin.venice.Command
- BACKUP_STRATEGY - Enum constant in enum class com.linkedin.venice.Arg
- BACKUP_STRATEGY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- BACKUP_VERSION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- BACKUP_VERSION_RETENTION_DAY - Enum constant in enum class 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 Class 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 - Enum constant in enum class com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
-
Clients using the new schema should be able to read data written with the old schema.
- BAD_GATEWAY - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- BAD_REQUEST - Enum constant in enum class com.linkedin.venice.exceptions.ErrorType
- BAD_REQUEST - Enum constant in enum class com.linkedin.venice.exceptions.ExceptionType
-
Deprecated.
- BAD_REQUEST - Enum constant in enum class com.linkedin.venice.listener.ReadQuotaEnforcementHandler.QuotaEnforcementResult
- BAD_REQUEST - Enum constant in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
BAD_REQUEST = 8;
- BAD_REQUEST - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- BAD_REQUEST - Static variable in class com.linkedin.venice.response.VeniceReadResponseStatus
- BAD_REQUEST_VALUE - Static variable in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
BAD_REQUEST = 8;
- 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 - Enum constant in enum class 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
- baseDimensionsMap - Variable in class com.linkedin.venice.client.stats.BasicClientStats
- BasicClientStats - Class in com.linkedin.venice.client.stats
-
This class offers some base metrics for clients currently used by thin, fast and DaVinci clients.
- BasicClientStats(MetricsRepository, String, RequestType, ClientType) - Constructor for class com.linkedin.venice.client.stats.BasicClientStats
- BasicClientStats.BasicClientMetricEntity - Enum Class in com.linkedin.venice.client.stats
- BasicClientStats.BasicClientTehutiMetricName - Enum Class in com.linkedin.venice.client.stats
-
Metric names for tehuti metrics used in this class.
- BasicConsumerStats - Class in com.linkedin.davinci.consumer.stats
- BasicConsumerStats(MetricsRepository, String, String) - Constructor for class com.linkedin.davinci.consumer.stats.BasicConsumerStats
- BasicConsumerStats.BasicConsumerMetricEntity - Enum Class in com.linkedin.davinci.consumer.stats
- BasicConsumerStats.BasicConsumerTehutiMetricName - Enum Class in com.linkedin.davinci.consumer.stats
-
Metric names for tehuti metrics used in this class.
- 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
- 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
- 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
- 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.
- 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
- 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 - Enum constant in enum class com.linkedin.venice.meta.Version.PushType
- BATCH_CREATE - Enum constant in enum class com.linkedin.venice.authorization.Method
- BATCH_DELETE - Enum constant in enum class com.linkedin.venice.authorization.Method
- BATCH_FOLLOWER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
- BATCH_GET - Enum constant in enum class com.linkedin.venice.authorization.Method
- BATCH_GET_LIMIT - Enum constant in enum class 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 - Enum constant in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
- BATCH_JOB_HEARTBEAT_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- BATCH_JOB_HEARTBEAT_STORE - Enum constant in enum class 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.vpj.VenicePushJobConstants
- BATCH_ONLY - Enum constant in enum class com.linkedin.venice.meta.VeniceUserStoreType
-
The data in batch-only stores will be populated by offline pushes/Samza reprocessing only.
- BATCH_PARTIAL_UPDATE - Enum constant in enum class com.linkedin.venice.authorization.Method
- BATCH_PROCESSING_REQUEST - Static variable in class com.linkedin.davinci.stats.IngestionStats
- BATCH_PROCESSING_REQUEST_ERROR - Static variable in class com.linkedin.davinci.stats.IngestionStats
- BATCH_PROCESSING_REQUEST_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
- BATCH_PROCESSING_REQUEST_RECORDS - Static variable in class com.linkedin.davinci.stats.IngestionStats
- BATCH_PROCESSING_REQUEST_SIZE - Static variable in class com.linkedin.davinci.stats.IngestionStats
- BATCH_REPLICATION_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
- BATCH_UPDATE - Enum constant in enum class com.linkedin.venice.authorization.Method
- BATCH_WRITE_LOSES - Enum constant in enum class 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 Class 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 Class in com.linkedin.venice.client.store.deserialization
-
This enum controls the behavior of the user payload deserialization phase of the batch get response handling.
- batchEndOfIncrementalPushReceived(String, int, long, List<String>) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
- batchEndOfIncrementalPushReceived(String, int, long, List<String>) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
- 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 interface com.linkedin.venice.protocols.VeniceReadServiceGrpc.AsyncService
- 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.
- BatchMaintenanceTaskRunner - Class in com.linkedin.venice
-
This class is a simple runnable which keeps fetching task from list and execute the assigned task.
- BatchMaintenanceTaskRunner(Map<String, Boolean>, String, List<String>, Function<String, Boolean>) - Constructor for class com.linkedin.venice.BatchMaintenanceTaskRunner
- batchNumBytes - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- batchPushEndSignalSent() - Method in class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- batchPushStartSignalSent() - Method in class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- batchReportIncPushStatusEnabled - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- 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
- batchUpdateReplicaIncPushStatus(String, int, String, long, List<String>) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
- batchUpdateReplicaIncPushStatus(String, int, String, long, List<String>) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
- batchUpdateReplicaIncPushStatus(String, List<String>, long) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
- BDB - Enum constant in enum class 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 - Enum constant in enum class com.linkedin.davinci.store.StoragePartitionAdjustmentTrigger
- beginAggregation(HttpMessage, ByteBuf) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpObjectAggregator
- 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(StoragePartitionConfig, Map<String, String>, Optional<Supplier<byte[]>>) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- beginBatchWrite(StoragePartitionConfig, Map<String, String>, Optional<Supplier<byte[]>>) - Method in interface com.linkedin.davinci.store.StorageEngine
-
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
- 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
- beginningPosition(PubSubTopicPartition, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- beginningPosition(PubSubTopicPartition, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
- between(int, String, int, int) - Static method in enum class 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(SocketAddress) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- bind(SocketAddress, ChannelPromise) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- bindService() - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceImplBase
- bindService() - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceImplBase
- bindService() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceImplBase
- bindService() - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceImplBase
- bindService(ClusterAdminOpsGrpcServiceGrpc.AsyncService) - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc
- bindService(StoreGrpcServiceGrpc.AsyncService) - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc
- bindService(VeniceControllerGrpcServiceGrpc.AsyncService) - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc
- bindService(VeniceReadServiceGrpc.AsyncService) - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
- BLACK_HOLE - Enum constant in enum class com.linkedin.venice.client.store.deserialization.BatchDeserializerType
-
Test mode used primarily for targeted benchmarking of non-serde code paths
- BLACK_HOLE - Enum constant in enum class 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_RECEIVE_MAX_TIMEOUT_IN_MIN - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_ACL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_CLIENT_READ_LIMIT_BYTES_PER_SEC - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_COMPLETED - Static variable in class com.linkedin.davinci.blobtransfer.BlobTransferUtils
- BLOB_TRANSFER_DISABLED_OFFSET_LAG_THRESHOLD - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_ENABLED - Enum constant in enum class com.linkedin.venice.Arg
- BLOB_TRANSFER_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- BLOB_TRANSFER_FAILED_NUM_RESPONSES - Static variable in class com.linkedin.davinci.stats.BlobTransferStats
- BLOB_TRANSFER_MANAGER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_MAX_CONCURRENT_SNAPSHOT_USER - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_MAX_TIMEOUT_IN_MIN - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_PEERS_CONNECTIVITY_FRESHNESS_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_SERVICE_WRITE_LIMIT_BYTES_PER_SEC - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_SNAPSHOT_CLEANUP_INTERVAL_IN_MINS - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_SNAPSHOT_RETENTION_TIME_IN_MIN - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_SSL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
- BLOB_TRANSFER_STATUS - Static variable in class com.linkedin.davinci.blobtransfer.BlobTransferUtils
- BLOB_TRANSFER_SUCCESSFUL_NUM_RESPONSES - Static variable in class com.linkedin.davinci.stats.BlobTransferStats
- BLOB_TRANSFER_THROUGHPUT - Static variable in class com.linkedin.davinci.stats.BlobTransferStats
- BLOB_TRANSFER_TIME - Static variable in class com.linkedin.davinci.stats.BlobTransferStats
- BLOB_TRANSFER_TOTAL_NUM_RESPONSES - Static variable in class com.linkedin.davinci.stats.BlobTransferStats
- BLOB_TRANSFER_TYPE - Static variable in class com.linkedin.davinci.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 manage the snapshot creation, for batch store and hybrid store.
- BlobSnapshotManager(StorageEngineRepository, StorageMetadataService) - Constructor for class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
The constructor for the BlobSnapshotManager, with default max concurrent users and snapshot retention time
- BlobSnapshotManager(StorageEngineRepository, StorageMetadataService, int, BlobTransferUtils.BlobTransferTableFormat, int) - Constructor for class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Constructor for the BlobSnapshotManager
- BlobTransferAclHandler - Class in com.linkedin.davinci.blobtransfer
-
Acl handler for blob transfer
- BlobTransferAclHandler() - Constructor for class com.linkedin.davinci.blobtransfer.BlobTransferAclHandler
- 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
- BlobTransferGlobalTrafficShapingHandlerHolder - Class in com.linkedin.davinci.blobtransfer
-
Singleton holder for the GlobalChannelTrafficShapingHandler.
- BlobTransferManager<T> - Interface in com.linkedin.davinci.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.
- BlobTransferManagerBuilder - Class in com.linkedin.davinci.blobtransfer
-
A builder class to build the blob transfer manager.
- BlobTransferManagerBuilder() - Constructor for class com.linkedin.davinci.blobtransfer.BlobTransferManagerBuilder
- BlobTransferNettyChannelInitializer - Class in com.linkedin.davinci.blobtransfer.server
- BlobTransferNettyChannelInitializer(String, int, BlobSnapshotManager, GlobalChannelTrafficShapingHandler, Optional<SSLFactory>, Optional<BlobTransferAclHandler>, int) - Constructor for class com.linkedin.davinci.blobtransfer.server.BlobTransferNettyChannelInitializer
- BlobTransferPartitionMetadata - Class in com.linkedin.davinci.blobtransfer
-
This class is the metadata of a partition in the blob transfer client
- BlobTransferPartitionMetadata() - Constructor for class com.linkedin.davinci.blobtransfer.BlobTransferPartitionMetadata
- BlobTransferPartitionMetadata(String, int, ByteBuffer, ByteBuffer) - Constructor for class com.linkedin.davinci.blobtransfer.BlobTransferPartitionMetadata
- BlobTransferPayload - Class in com.linkedin.davinci.blobtransfer
-
POJO to hold the payload for blob transfer related informartion
- BlobTransferPayload(String, String, int, int, BlobTransferUtils.BlobTransferTableFormat) - Constructor for class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- BlobTransferStats - Class in com.linkedin.davinci.stats
-
Class that exposes stats related to blob transfers
- BlobTransferStats() - Constructor for class com.linkedin.davinci.stats.BlobTransferStats
- BlobTransferStatsReporter - Class in com.linkedin.davinci.stats
-
This class is the reporting class for stats class
BlobTransferStats
Metrics reporting logics are registered intoMetricsRepository
here and send out to external metrics collection/visualization system. - BlobTransferStatsReporter(MetricsRepository, String, String) - Constructor for class com.linkedin.davinci.stats.BlobTransferStatsReporter
- BlobTransferStatsReporter.IngestionStatsGauge - Class in com.linkedin.davinci.stats
- BlobTransferUtils - Class in com.linkedin.davinci.blobtransfer
- BlobTransferUtils() - Constructor for class com.linkedin.davinci.blobtransfer.BlobTransferUtils
- BlobTransferUtils.BlobTransferTableFormat - Enum Class in com.linkedin.davinci.blobtransfer
- BlobTransferUtils.BlobTransferType - Enum Class in com.linkedin.davinci.blobtransfer
- BLOCK_BASED_TABLE - Enum constant in enum class com.linkedin.davinci.blobtransfer.BlobTransferUtils.BlobTransferTableFormat
- BLOCK_STRATEGY - Static variable in class com.linkedin.venice.throttle.EventThrottler
- BLOCKING - Enum constant in enum class com.linkedin.venice.client.store.deserialization.BatchDeserializerType
-
Only supported working mode
- BLOCKING - Enum constant in enum class 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, Schema, Schema, Schema, DaVinciRecordTransformerConfig) - 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
- 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 Class in com.linkedin.venice.utils.concurrent
- BOOLEAN - Enum constant in enum class 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
- booleanAndOptionalBoolean() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- booleanBooleanCompression() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- booleanChecksumType() - 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.router.impl.netty4.Router4Impl
- BOOTSTRAP_TO_ONLINE_TIMEOUT_IN_HOUR - Enum constant in enum class 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
- BOOTSTRAPPING - Enum constant in enum class com.linkedin.venice.pushstatushelper.PushStatusStoreReader.InstanceStatus
- 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.
- BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl<K,
V> - Class in com.linkedin.davinci.consumer - BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl(ChangelogClientConfig) - Constructor for class com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl
- BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl.DaVinciRecordTransformerBootstrappingChangelogConsumer - Class in com.linkedin.davinci.consumer
- 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 - Enum constant in enum class 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 the real-time or version topic partition.
- 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, VeniceCompressor) - Method in class com.linkedin.davinci.utils.ChunkAssembler
-
Buffers and assembles chunks of a record.
- 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 Class in com.linkedin.venice.meta
-
Enums of the policies used to decide how buffer replay start timestamps are calculated.
- bufferStorageEngine - Variable in class com.linkedin.davinci.utils.ChunkAssembler
- 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.blobtransfer.BlobTransferManagerBuilder
- build() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerConfig.Builder
- build() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- build() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies.Builder
- build() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.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.fastclient.meta.InstanceHealthMonitorConfig.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.httpclient5.HttpClient5Utils.HttpClient5Builder
- build() - Method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
- build() - Method in class com.linkedin.venice.meta.MaterializedViewParameters.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- build() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- 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.pubsub.PubSubAdminAdapterContext.Builder
- build() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext.Builder
- build() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext.Builder
- build() - Method in class com.linkedin.venice.reliability.LoadController.Builder
- build() - Method in class com.linkedin.venice.server.VeniceServerContext.Builder
- build() - Method in class com.linkedin.venice.spark.input.hdfs.VeniceHdfsInputScanBuilder
- build() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig.Builder
- build() - Method in class com.linkedin.venice.utils.CollectionUtils.MapBuilder
- build() - Method in class com.linkedin.venice.utils.InMemoryLogAppender.Builder
- build() - Method in class com.linkedin.venice.utils.LogContext.Builder
-
Builds a new
LogContext
using the provided values. - 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.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceBlockingStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceFutureStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceBlockingStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceFutureStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceBlockingStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceFutureStub
- build(Channel, CallOptions) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceStub
- 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
- buildChannelCredentials(SSLFactory) - Static method in class com.linkedin.venice.grpc.GrpcUtils
- 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 class com.linkedin.alpini.base.misc.HeaderUtils
- buildContentType(String, String, Iterator<Map.Entry<String, String>>) - Static method in enum class 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() - 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.fastclient.meta.InstanceHealthMonitorConfig
- 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.client.DaVinciRecordTransformerConfig.Builder
- Builder() - Constructor for class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- Builder() - Constructor for class com.linkedin.venice.controller.ControllerRequestHandlerDependencies.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.fastclient.meta.InstanceHealthMonitorConfig.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.pubsub.PubSubAdminAdapterContext.Builder
- Builder() - Constructor for class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext.Builder
- Builder() - Constructor for class com.linkedin.venice.pubsub.PubSubProducerAdapterContext.Builder
- Builder() - Constructor for class com.linkedin.venice.reliability.LoadController.Builder
- Builder() - Constructor for class com.linkedin.venice.server.VeniceServerContext.Builder
- Builder() - Constructor for class com.linkedin.venice.stats.VeniceMetricsConfig.Builder
- Builder() - Constructor for class com.linkedin.venice.utils.InMemoryLogAppender.Builder
- Builder() - Constructor for class com.linkedin.venice.utils.LogContext.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.meta.MaterializedViewParameters.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) - Constructor for class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Builder
- Builder(String, String, String, String, LocalDateTime, ControllerClient, String, Optional<SSLFactory>, boolean) - Constructor for class com.linkedin.venice.datarecovery.StoreRepushCommand.Params.Builder
- Builder(String, Map<String, String>) - Constructor for class com.linkedin.venice.meta.MaterializedViewParameters.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
- buildHelixManagerProperty(VeniceServerConfig) - Method in class com.linkedin.davinci.helix.HelixParticipationService
- 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.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- buildPartial() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- 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
- buildPutPayload(byte[], int, PutMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
- 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(BasicHttpRequest, 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.
- buildStoreNameWithVersion(int) - Method in class com.linkedin.venice.duckdb.DuckDBDaVinciRecordTransformer
- 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 - Enum constant in enum class 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
- 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 - Enum constant in enum class 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
- bytesBeforeUnwritable() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- bytesBeforeWritable() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- 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
- CACHE - Enum constant in enum class 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
- cacheStoreConfigFromRemote(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
-
Get the store cluster config from system store and update the local cache with it.
- cacheStoreSchema(String, StoreMetaValue) - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- CachingDaVinciClientFactory - Class in com.linkedin.davinci.client.factory
- 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, Executor) - 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, PubSubTopic, List<CharSequence>) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- calculateLeaderUpstreamOffsetWithTopicSwitch(PartitionConsumptionState, 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
- calculateTopicHashCode(PubSubTopic) - Static method in class com.linkedin.venice.utils.Utils
- 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.spark.datawriter.writer.SparkPartitionWriterFactory
- call(Row) - Method in class com.linkedin.venice.spark.datawriter.recordprocessor.SparkInputRecordProcessorFactory
- CALL_COUNT - Enum constant in enum class com.linkedin.venice.client.stats.BasicClientStats.BasicClientMetricEntity
-
Count of all requests during response handling along with response codes
- CALL_COUNT - Enum constant in enum class com.linkedin.venice.router.stats.RouterMetricEntity
-
Count of all requests during response handling along with response codes
- CALL_COUNT_DVC - Enum constant in enum class com.linkedin.venice.client.stats.BasicClientStats.BasicClientMetricEntity
-
Count of all DaVinci requests: as DaVinci is local reads, we do not track HTTP response codes But keeping the same name call_count across all clients for consistency
- CALL_TIME - Enum constant in enum class com.linkedin.venice.client.stats.BasicClientStats.BasicClientMetricEntity
-
Latency based on all responses
- CALL_TIME - Enum constant in enum class com.linkedin.venice.router.stats.RouterMetricEntity
-
Latency based on all responses
- CALL_TIME_DVC - Enum constant in enum class com.linkedin.venice.client.stats.BasicClientStats.BasicClientMetricEntity
-
Latency for all DaVinci Client responses
- callable(Runnable) - Static method in enum class 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 class 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 class 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 class 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
- callConstructor(Class<T>, Class<?>[], Object[]) - Static method in class com.linkedin.venice.utils.ReflectUtils
-
Call the class constructor with the given arguments
- CAMEL_CASE - Enum constant in enum class com.linkedin.venice.stats.VeniceOpenTelemetryMetricNamingFormat
-
Alternate format for attribute names.
- 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 or due to the job exceeding bootstrapToOnlineTimeoutInHours.
- 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.davinci.utils.LockAssistedCompletableFuture
- CANCELLATION_EXCEPTION - Enum constant in enum class 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 class com.linkedin.venice.meta.VersionStatus
-
check if a status can be deleted immediately.
- canEqual(Object) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- 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.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 - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
- catchUpVersionTopicOffsetLag(String, int) - Method in class com.linkedin.davinci.notifier.LogNotifier
- catchUpVersionTopicOffsetLag(String, int) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
- cause(Throwable, Class<E>) - Static method in enum class 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 - Enum constant in enum class com.linkedin.davinci.store.view.VeniceViewWriter.ViewWriterType
- CHANGE_CAPTURE_VIEW_WRITER_CLASS_NAME - Static variable in class com.linkedin.venice.views.ChangeCaptureView
- CHANGE_DATA_CAPTURE_CLIENT - Enum constant in enum class com.linkedin.venice.stats.ClientType
- changeCaptureStats - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- ChangeCaptureView - Class in com.linkedin.venice.views
- ChangeCaptureView(Properties, String, Map<String, String>) - Constructor for class com.linkedin.venice.views.ChangeCaptureView
- ChangeCaptureViewWriter - Class in com.linkedin.davinci.store.view
- ChangeCaptureViewWriter(VeniceConfigLoader, Version, Schema, Map<String, String>, VeniceWriterFactory) - 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
- CHANGELOG_CONSUMER - Enum constant in enum class com.linkedin.venice.acl.VeniceComponent
- 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_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.venice.listener.ServerConnectionStatsHandler
- 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.davinci.blobtransfer.client.P2PFileTransferClientHandler
- channelInactive(ChannelHandlerContext) - Method in class com.linkedin.davinci.blobtransfer.server.P2PFileTransferServerHandler
-
This method is called when the channel is inactive.
- 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.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
- channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpObjectToBasicHttpObjectAdapter
- channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.HttpVersionFilter
- channelRead(ChannelHandlerContext, Object) - Method in class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
- 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.http2.EspressoHttp2MultiplexHandler
- channelRead0(ChannelHandlerContext, RouterRequest) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.davinci.blobtransfer.server.P2PFileTransferServerHandler
-
This method is called with the request that is received from the client.
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerHandler
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionReportHandler
- channelRead0(ChannelHandlerContext, FullHttpRequest) - Method in class com.linkedin.venice.listener.RouterRequestHttpHandler
- channelRead0(ChannelHandlerContext, FullHttpResponse) - Method in class com.linkedin.davinci.blobtransfer.client.P2PMetadataTransferHandler
- channelRead0(ChannelHandlerContext, HttpObject) - Method in class com.linkedin.davinci.blobtransfer.client.P2PFileTransferClientHandler
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.davinci.blobtransfer.BlobTransferAclHandler
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerAclHandler
- channelRead0(ChannelHandlerContext, HttpRequest) - Method in class com.linkedin.venice.acl.handler.AbstractStoreAclHandler
-
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.ServerLoadControllerHandler
- 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
- 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.http2.EspressoHttp2MultiplexHandler
-
Notifies any child streams of the read completion.
- channelRegistered(ChannelHandlerContext) - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
- channelWritabilityChanged(ChannelHandlerContext) - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
- channelWritabilityChanged(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
- CHECK_DATABASE_INTEGRITY - Enum constant in enum class com.linkedin.davinci.store.StoragePartitionAdjustmentTrigger
- CHECK_DISK_SPACE - Enum constant in enum class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Step
- CHECK_FABRIC_BUILDOUT_STATUS - Enum constant in enum class com.linkedin.venice.Command
- CHECK_RESOURCE_CLEANUP_FOR_STORE_CREATION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- CHECK_SUM_TYPE - Static variable in class com.linkedin.venice.writer.VeniceWriter
- checkAccess(String, X509Certificate, String, String) - Method in class com.linkedin.venice.acl.handler.AbstractStoreAclHandler
-
N.B.: This function is called on the hot path, so it's important to make it as efficient as possible.
- checkAllPartitionsQuota() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
-
Enforce partition level quota for the map.
- checkAndHandleUpstreamOffsetRewind(PartitionConsumptionState, DefaultPubSubMessage, long, long, LeaderFollowerStoreIngestionTask) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- checkAndLogIfLagIsAcceptableForHybridStore(PartitionConsumptionState, long, long, boolean, LagType) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
-
Checks whether the lag is acceptable for hybrid stores
- checkAndLogIfLagIsAcceptableForHybridStore(PartitionConsumptionState, long, long, boolean, LagType) - 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
- checkAndMaybeLogHeartbeatDelay() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- checkAndMaybeLogHeartbeatDelayMap(Map<String, Map<Integer, Map<Integer, Map<String, HeartbeatTimeStampEntry>>>>) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- checkAndThrowSpecificException(RocksDBException) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- 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(int, Map<String, String>, StoragePartitionConfig) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- checkDatabaseIntegrity(int, Map<String, String>, StoragePartitionConfig) - Method in interface com.linkedin.davinci.store.StorageEngine
-
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
- 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 class 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
- 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(PartitionTracker.TopicType, DefaultPubSubMessage, Optional<PartitionTracker.DIVErrorMetricCallback>, long) - Method in class com.linkedin.davinci.validation.PartitionTracker
- checkMissingMessage(DefaultPubSubMessage, Optional<PartitionTracker.DIVErrorMetricCallback>) - Method in class com.linkedin.davinci.validation.DataIntegrityValidator
-
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.
- checkpoint(String) - Method in class com.linkedin.venice.BatchMaintenanceTaskRunner
- CHECKPOINT - Enum constant in enum class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read.SeekWhence
- CHECKPOINT_FILE - Enum constant in enum class com.linkedin.venice.Arg
- checkpointingSupportedCheckSumTypes() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- CheckPointProperties - Class in com.linkedin.venice.beam.consumer
-
Properties used by
VeniceChangelogConsumer
to seek checkpoints. - CheckPointProperties(Set<VeniceChangeCoordinate>, long, String) - Constructor for class com.linkedin.venice.beam.consumer.CheckPointProperties
- 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: 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, StoreRequestHandler) - Method in class com.linkedin.venice.controller.server.CreateStore
- checkResourceCleanupForStoreCreation(ClusterStoreGrpcInfo) - Method in class com.linkedin.venice.controller.server.StoreRequestHandler
- checkResourceCleanupForStoreCreation(ClusterStoreGrpcInfo) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceBlockingStub
- checkResourceCleanupForStoreCreation(ClusterStoreGrpcInfo) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceFutureStub
- checkResourceCleanupForStoreCreation(ClusterStoreGrpcInfo, StreamObserver<ResourceCleanupCheckGrpcResponse>) - Method in class com.linkedin.venice.controller.grpc.server.StoreGrpcServiceImpl
- checkResourceCleanupForStoreCreation(ClusterStoreGrpcInfo, StreamObserver<ResourceCleanupCheckGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.AsyncService
- checkResourceCleanupForStoreCreation(ClusterStoreGrpcInfo, StreamObserver<ResourceCleanupCheckGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceStub
- 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.
- checkSignalAndAdjustThrottler() - Method in class com.linkedin.davinci.kafka.consumer.VeniceAdaptiveIngestionThrottler
- checkState(boolean) - Static method in enum class com.linkedin.alpini.base.misc.Preconditions
- checkState(boolean, String) - Static method in enum class 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
- CHECKSUM_TYPES - Static variable in class com.linkedin.venice.utils.DataProviderUtils
- 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 Class 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.
- checkVersionSRTopic(String, boolean) - Static method in interface com.linkedin.venice.meta.Version
- checkWhetherStoragePartitionsShouldBeKeptOrNot(SafeHelixManager) - Method in class com.linkedin.davinci.storage.StorageService
- checkWhetherToCloseUnusedVeniceWriter(Lazy<VeniceWriter<byte[], byte[], byte[]>>, Lazy<VeniceWriter<byte[], byte[], byte[]>>, Map<Integer, PartitionConsumptionState>, Runnable, String) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- checkWhetherToStartEOPProcedures(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 - Enum constant in enum class 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
- ChildWriterProducerCallback() - Constructor for class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.ChildWriterProducerCallback
- CHUNK - Enum constant in enum class 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
- CHUNK_SCHEMA_ID - Static variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- 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(StorageEngine, boolean) - 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 - Enum constant in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
-
Suffix appended to the end of all keys in a store-version where chunking is enabled.
- CHUNKED_RECORD_COUNT - Enum constant in enum class com.linkedin.davinci.consumer.stats.BasicConsumerStats.BasicConsumerMetricEntity
-
Measures the count of chunked records consumed
- CHUNKED_RECORD_FAIL_COUNT - Enum constant in enum class com.linkedin.davinci.consumer.stats.BasicConsumerStats.BasicConsumerTehutiMetricName
- CHUNKED_RECORD_SUCCESS_COUNT - Enum constant in enum class com.linkedin.davinci.consumer.stats.BasicConsumerStats.BasicConsumerTehutiMetricName
- CHUNKED_VALUE_MANIFEST - Enum constant in enum class 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
- 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 - Enum constant in enum class 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 Class 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[], MessageType, 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
- ClassSizeEstimator - Class in com.linkedin.venice.memory
-
Utility class to help in implementing
Measurable.getHeapSize()
. - ClassUtil - Class in com.linkedin.alpini.base.misc
-
Utilities for Classes / reflection.
- CLEAN_EXECUTION_IDS - Enum constant in enum class com.linkedin.venice.Command
- CLEAN_EXECUTION_IDS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- cleanExecutionIdMap(String, Set<String>) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
- cleanExecutionIdMap(String, Set<String>) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
- cleanExecutionIdMap(String, Set<String>) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
- cleanExecutionIds(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- cleanExecutionIds(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- CleanExecutionIdsResponse - Class in com.linkedin.venice.controllerapi
- CleanExecutionIdsResponse() - Constructor for class com.linkedin.venice.controllerapi.CleanExecutionIdsResponse
- cleanHeaderValue(CharSequence) - Static method in enum class 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 class com.linkedin.alpini.base.misc.HeaderUtils
-
Cleans the status message and if no cleanup is required, returns the same String object.
- cleanTableName(String) - Static method in class com.linkedin.venice.sql.SQLUtils
-
This function should encapsulate the handling of any illegal characters (by either failing or converting them).
- CLEANUP_INSTANCE_CUSTOMIZED_STATES - Enum constant in enum class com.linkedin.venice.Command
- CLEANUP_INSTANCE_CUSTOMIZED_STATES - Enum constant in enum class 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
- cleanupMigrationRecord(String) - Method in class com.linkedin.venice.controller.multitaskscheduler.StoreMigrationManager
- cleanupOutOfRetentionSnapshot(String, int) - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
A regular cleanup task to clean up the snapshot folder which is out of retention time.
- cleanupSnapshot() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Cleans up the snapshot
- cleanupSnapshot() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- cleanupSnapshot() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- cleanupSnapshot() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- cleanupSnapshot() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- cleanupSnapshot(String) - Static method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
-
A util method to clean up snapshot;
- cleanupSnapshot(String, int) - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Cleanup the snapshot for a particular partition
- 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.netty4.http2.Http1Headers
- clear() - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- 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.NativeMetadataRepositoryViewAdapter
- clear() - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- 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.HelixReadOnlyStoreViewConfigRepositoryAdapter
- 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.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- clear() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- 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.collections.MemoryBoundBlockingQueue
- 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 - Enum constant in enum class com.linkedin.venice.meta.IngestionMetadataUpdateType
- CLEAR_STORE_VERSION_STATE - Enum constant in enum class com.linkedin.venice.meta.IngestionMetadataUpdateType
- clearAccessPermission() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional string accessPermission = 6;
- clearAccessPermissions() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
-
string accessPermissions = 2;
- clearAccessPermissions() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
-
string accessPermissions = 3;
- 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
- clearAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
-
int64 adminCommandExecutionId = 2;
- clearAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
int64 adminCommandExecutionId = 2;
- clearAdminOperationProtocolVersion() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 adminOperationProtocolVersion = 6;
- clearAdminOperationProtocolVersion() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
-
int64 adminOperationProtocolVersion = 2;
- 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() - Method in class com.linkedin.davinci.utils.ChunkAssembler
- clearCachedPartitions(Version) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
-
The cluster name
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
The cluster name
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
-
string clusterName = 1;
- clearClusterName() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional string clusterName = 4;
- clearCompressionStrategy() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
uint32 compressionStrategy = 3;
- clearD2Service() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string d2Service = 3;
- clearData() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
bytes data = 2;
- clearDescription() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
optional string description = 3;
- clearErrorCode() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
uint32 errorCode = 6;
- clearErrorMessage() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
string errorMessage = 2;
- clearErrorMessage() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
string errorMessage = 7;
- clearErrorType() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional .com.linkedin.venice.protocols.controller.ControllerGrpcErrorType errorType = 3;
- clearExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 executionId = 2;
- clearFabricToExecutionStatusMap() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
- clearField(Descriptors.FieldDescriptor) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
- clearGrpcUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
gRPC URL for leader controller
- clearHasLingeringResources() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
bool hasLingeringResources = 2;
- clearHttpsUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
SSL-enabled leader controller URL
- clearHttpUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
Leader controller URL
- clearIngestionKillMessageAndVerify(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Clear KILL messages from a participant system store.
- 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;
- clearIsSystemStore() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional bool isSystemStore = 5;
- clearKeyBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
used for batch get
- clearKeySchema() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
string keySchema = 2;
- clearKeyString() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
used for single get
- clearLastSuccessfulAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
-
int64 lastSuccessfulAdminCommandExecutionId = 2;
- clearLogContext() - Static method in class com.linkedin.venice.utils.LogContext
- clearMetadata() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- clearMetadata() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- clearMethod() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
string method = 10;
- clearOffset() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 offset = 4;
- 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.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
- clearOneof(Descriptors.OneofDescriptor) - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
- clearOperation() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string operation = 3;
- clearOwner() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional string owner = 4;
- clearOwner() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
-
string owner = 2;
- clearPartition() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
uint32 partition = 1;
- clearPartition(int) - Method in class com.linkedin.davinci.validation.DataIntegrityValidator
-
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.
- clearPartitionOffset(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- clearPartitionOffset(int) - Method in interface com.linkedin.davinci.store.StorageEngine
-
Clear the offset associated with the partitionId in the metadata partition.
- clearPendingReportIncPushVersionList() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- clearPubSubBootstrapServers() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
optional string pubSubBootstrapServers = 6;
- 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;
- clearSecureGrpcUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
Secure gRPC URL for leader controller
- clearServerD2Service() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string serverD2Service = 4;
- clearStartTime() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string startTime = 4;
- clearStatusCode() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
uint32 statusCode = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreInfo() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- clearStoreName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional string storeName = 3;
- clearStoreName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
-
optional string storeName = 2;
- clearStoreName() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
-
string storeName = 2;
- clearStoreName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
-
string storeName = 1;
- clearStoreName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string storeName = 2;
- clearStoreName() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional string storeName = 5;
- clearStoreVersionState() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Clear the store version state in the metadata partition.
- clearStoreVersionState() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- clearStoreVersionState() - Method in interface com.linkedin.davinci.store.StorageEngine
-
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 .
- clearStoreVersionState(String) - Method in class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
-
This will clear all metadata, including store-version state and partition states, tied to .
- clearStoreVersionState(String) - Method in class com.linkedin.venice.offsets.InMemoryStorageMetadataService
- clearUpstreamOffset() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 upstreamOffset = 5;
- clearValueSchema() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
string valueSchema = 3;
- clearZkAddress() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
optional string zkAddress = 5;
- 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 - Enum constant in enum class com.linkedin.venice.Arg
- CLIENT_DECOMPRESSION_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- CLIENT_ERROR - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusCodeCategory
- CLIENT_METRIC_ENTITIES - Static variable in class com.linkedin.venice.client.stats.BasicClientStats
- 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_REQUEST_BASED_METADATA_REPOSITORY - Static variable in class com.linkedin.venice.ConfigKeys
-
A config for Da-Vinci clients to use request based metadata repository.
- 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.
- 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
- 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
- ClientMetricEntity - Enum Class in com.linkedin.venice.client.stats
- ClientRoutingStrategyType - Enum Class 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, ClientType) - Constructor for class com.linkedin.venice.client.stats.ClientStats
- ClientStats.ClientTehutiMetricName - Enum Class in com.linkedin.venice.client.stats
-
Metric names for tehuti metrics used in this class.
- ClientTestUtils - Class in com.linkedin.venice.fastclient.utils
- ClientTestUtils() - Constructor for class com.linkedin.venice.fastclient.utils.ClientTestUtils
- ClientTestUtils.FastClientHTTPVariant - Enum Class in com.linkedin.venice.fastclient.utils
- clientType - Variable in class com.linkedin.venice.client.stats.BasicClientStats
- ClientType - Enum Class in com.linkedin.venice.stats
- clipAndFilterNamespace(String) - Method in class com.linkedin.venice.utils.VeniceProperties
-
Extracts properties that begin with the specified namespace.
- clipAndFilterNamespace(Set<String>) - Method in class com.linkedin.venice.utils.VeniceProperties
-
Extracts properties that begin with any of the specified namespaces.
- CLOCK - Enum constant in enum class com.linkedin.davinci.store.rocksdb.RocksDBBlockCacheImplementations
-
ClockCache implements the CLOCK algorithm.
- 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.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- clone() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- 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.pubsub.PubSubTopicConfiguration
- clone() - Method in class com.linkedin.venice.schema.SchemaEntry
- 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
- cloneDrainerDivProducerStates(int, DataIntegrityValidator) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
We should only allow
StoreIngestionTask
to accessStoreIngestionTask.drainerDiv
; 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. - clonePushStatus() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- cloneRoutesClusterConfig() - Method in class com.linkedin.venice.meta.RoutersClusterConfig
- cloneRtProducerStates(int, String) - Method in class com.linkedin.davinci.validation.DataIntegrityValidator
-
Returns the RT DIV state for a given partition and broker URL pair.
- cloneRtProducerStates(PartitionTracker, String) - Method in class com.linkedin.davinci.validation.PartitionTracker
-
Clone the rtSegments to the destination PartitionTracker.
- 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
- cloneStoreProperties() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- 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.
- cloneVtProducerStates(int) - Method in class com.linkedin.davinci.validation.DataIntegrityValidator
-
Returns the VT DIV state and latest consumed vt offset for a given partition.
- cloneVtProducerStates(int, DataIntegrityValidator) - Method in class com.linkedin.davinci.validation.DataIntegrityValidator
- cloneVtProducerStates(PartitionTracker) - Method in class com.linkedin.davinci.validation.PartitionTracker
-
Clone the vtSegments and LCVO to the destination PartitionTracker.
- ClosableHttpAsyncClientWithConnManager(CloseableHttpAsyncClient, PoolingNHttpClientConnectionManager) - Constructor for class com.linkedin.venice.httpclient.HttpClientUtils.ClosableHttpAsyncClientWithConnManager
- close() - Method in interface com.linkedin.davinci.blobtransfer.BlobTransferManager
-
Close the blob transfer manager and related resources
- close() - Method in class com.linkedin.davinci.blobtransfer.client.NettyFileTransferClient
- close() - Method in class com.linkedin.davinci.blobtransfer.NettyP2PBlobTransferManager
- close() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- close() - Method in class com.linkedin.davinci.client.BlockingDaVinciRecordTransformer
- close() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- close() - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- close() - Method in class com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl.DaVinciRecordTransformerBootstrappingChangelogConsumer
- 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.DelegatingStorageEngine
- 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 interface com.linkedin.davinci.store.StorageEngine
- close() - Method in class com.linkedin.davinci.store.StorageEngineFactory
-
Close the storage configuration
- close() - Method in class com.linkedin.venice.blobtransfer.DaVinciBlobFinder
- 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.NoopCompressor
- close() - Method in class com.linkedin.venice.compression.VeniceCompressor
- 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.DeadStoreStatsPreFetchTask
- 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.VeniceControllerStateModel
-
Shutdown the internal executor service.
- close() - Method in class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
-
Close all
VeniceControllerStateModel
created by the factory. - 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.duckdb.DuckDBDaVinciRecordTransformer
- 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.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 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.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.task.datawriter.CompositeVeniceWriter
- 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 interface com.linkedin.venice.jobs.ComputeJob
- 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.spark.datawriter.jobs.AbstractDataWriterSparkJob
- close() - Method in class com.linkedin.venice.spark.input.VeniceAbstractPartitionReader
- close() - Method in class com.linkedin.venice.stats.VeniceMetricsRepository
- close() - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- 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.writer.VeniceWriter
- close() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- close(boolean) - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
- close(boolean) - Method in class com.linkedin.davinci.store.view.MaterializedViewWriter
- close(boolean) - Method in class com.linkedin.venice.hadoop.task.datawriter.CompositeVeniceWriter
- close(boolean) - Method in class com.linkedin.venice.views.VeniceView
- 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 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.pubsub.api.PubSubProducerAdapterConcurrentDelegator
- close(long) - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterDelegator
- 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(ChannelPromise) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.venice.writer.VeniceWriter
- CloseableThreadLocal<T extends 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.
- closeAllStorageEngines() - Method in class com.linkedin.davinci.storage.StorageService
- closeAsync(boolean) - Method in class com.linkedin.venice.writer.VeniceWriter
- closeAsync(boolean, boolean) - Method in class com.linkedin.venice.writer.VeniceWriter
- closed - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- closeFuture() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- closeInternal() - Method in class com.linkedin.venice.compression.GzipCompressor
- closeInternal() - Method in class com.linkedin.venice.compression.NoopCompressor
- closeInternal() - Method in class com.linkedin.venice.compression.VeniceCompressor
- closeInternal() - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- closeMetadataPartition() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- closeMetadataPartition() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- closeMetadataPartition() - Method in interface com.linkedin.davinci.store.StorageEngine
- closePartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- closePartition(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- closePartition(int) - Method in interface com.linkedin.davinci.store.StorageEngine
- closePartition(int) - Method in class com.linkedin.venice.writer.VeniceWriter
-
Close a single partition from this writer.
- closeQuietlyWithErrorLogged(Closeable...) - Static method in class com.linkedin.venice.utils.Utils
- closeStorageEngine(StorageEngine) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
- closeStorageEngine(StorageEngine) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
- closeStorageEngine(StorageEngine) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- closeStorageEngine(StorageEngine) - 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
- closeVeniceViewWriters(boolean) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- closeVeniceViewWriters(boolean) - 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
- cluster - Variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
-
The Venice cluster of the store.
- CLUSTER - Enum constant in enum class com.linkedin.venice.Arg
- CLUSTER - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- CLUSTER_BATCH_TASK - Enum constant in enum class com.linkedin.venice.Command
- CLUSTER_CONFIG - Static variable in class com.linkedin.venice.zk.VeniceZkPaths
- CLUSTER_DEST - Enum constant in enum class com.linkedin.venice.Arg
- CLUSTER_DEST - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- CLUSTER_DISCOVERY - Enum constant in enum class 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 - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- CLUSTER_HEALTH_INSTANCES - Enum constant in enum class com.linkedin.venice.Command
- CLUSTER_HEALTH_STORES - Enum constant in enum class com.linkedin.venice.Command
- CLUSTER_HEALTH_STORES - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- CLUSTER_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- CLUSTER_LIST - Enum constant in enum class com.linkedin.venice.Arg
- CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
- CLUSTER_NAME_METADATA_KEY - Static variable in class com.linkedin.venice.controller.grpc.ControllerGrpcConstants
- CLUSTER_PROPERTIES_FILE - Static variable in class com.linkedin.davinci.config.VeniceConfigLoader
- CLUSTER_SRC - Enum constant in enum class 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
- ClusterAdminOpsGrpcServiceGrpc - Class in com.linkedin.venice.protocols.controller
- ClusterAdminOpsGrpcServiceGrpc.AsyncService - Interface in com.linkedin.venice.protocols.controller
- ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceBlockingStub - Class in com.linkedin.venice.protocols.controller
-
A stub to allow clients to do synchronous rpc calls to service ClusterAdminOpsGrpcService.
- ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceFutureStub - Class in com.linkedin.venice.protocols.controller
-
A stub to allow clients to do ListenableFuture-style rpc calls to service ClusterAdminOpsGrpcService.
- ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceImplBase - Class in com.linkedin.venice.protocols.controller
-
Base class for the server implementation of the service ClusterAdminOpsGrpcService.
- ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceStub - Class in com.linkedin.venice.protocols.controller
-
A stub to allow clients to do asynchronous rpc calls to service ClusterAdminOpsGrpcService.
- ClusterAdminOpsGrpcServiceImpl - Class in com.linkedin.venice.controller.grpc.server
- ClusterAdminOpsGrpcServiceImpl(ClusterAdminOpsRequestHandler, VeniceControllerAccessManager) - Constructor for class com.linkedin.venice.controller.grpc.server.ClusterAdminOpsGrpcServiceImpl
- ClusterAdminOpsGrpcServiceImplBase() - Constructor for class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceImplBase
- ClusterAdminOpsGrpcServiceOuterClass - Class in com.linkedin.venice.protocols.controller
- ClusterAdminOpsRequestHandler - Class in com.linkedin.venice.controller.server
- ClusterAdminOpsRequestHandler(ControllerRequestHandlerDependencies) - Constructor for class com.linkedin.venice.controller.server.ClusterAdminOpsRequestHandler
- 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, LogContext) - 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
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- CLUSTERNAME_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- ClusterRoutes - Class in com.linkedin.venice.controller.server
- ClusterRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.ClusterRoutes
- ClusterRouteStats - Class in com.linkedin.venice.fastclient.stats
- ClusterRouteStats.RouteStats - Class in com.linkedin.venice.fastclient.stats
-
Per-route request metrics.
- 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
- ClusterStoreGrpcInfo - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- ClusterStoreGrpcInfo.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- ClusterStoreGrpcInfoOrBuilder - Interface in com.linkedin.venice.protocols.controller
- clusterStoreRepositoryPath - Variable in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- code - Variable in enum class com.linkedin.venice.stats.StatsErrorCode
- code() - Method in exception com.linkedin.alpini.base.misc.ExceptionWithStatus
- Coder(PubSubPositionDeserializer) - Constructor for class com.linkedin.venice.beam.consumer.VeniceCheckpointMark.Coder
- 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 Class in com.linkedin.alpini.base.misc
- CollectionUtils - Class in com.linkedin.venice.utils
- CollectionUtils() - Constructor for class com.linkedin.venice.utils.CollectionUtils
- CollectionUtils.MapBuilder<K,
V> - Class in com.linkedin.venice.utils - coloStatus - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
- ColumnDefinition - Class in com.linkedin.venice.sql
- ColumnDefinition(String, JDBCType, boolean, IndexType, int) - Constructor for class com.linkedin.venice.sql.ColumnDefinition
- ColumnDefinition(String, JDBCType, boolean, IndexType, String, String, int) - Constructor for class com.linkedin.venice.sql.ColumnDefinition
- ColumnDefinition(String, JDBCType, int) - Constructor for class com.linkedin.venice.sql.ColumnDefinition
- 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.registry - package com.linkedin.alpini.base.registry
- com.linkedin.alpini.base.registry.impl - package com.linkedin.alpini.base.registry.impl
- com.linkedin.alpini.base.ssl - package com.linkedin.alpini.base.ssl
- com.linkedin.alpini.io.ssl - package com.linkedin.alpini.io.ssl
- 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.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.blobtransfer.client - package com.linkedin.davinci.blobtransfer.client
- com.linkedin.davinci.blobtransfer.server - package com.linkedin.davinci.blobtransfer.server
- 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.beam.consumer - package com.linkedin.venice.beam.consumer
- com.linkedin.venice.blobtransfer - package com.linkedin.venice.blobtransfer
- 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.grpc - package com.linkedin.venice.controller.grpc
- com.linkedin.venice.controller.grpc.server - package com.linkedin.venice.controller.grpc.server
- com.linkedin.venice.controller.grpc.server.interceptor - package com.linkedin.venice.controller.grpc.server.interceptor
- 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.logcompaction - package com.linkedin.venice.controller.logcompaction
- com.linkedin.venice.controller.migration - package com.linkedin.venice.controller.migration
- com.linkedin.venice.controller.multitaskscheduler - package com.linkedin.venice.controller.multitaskscheduler
- com.linkedin.venice.controller.repush - package com.linkedin.venice.controller.repush
- 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.duckdb - package com.linkedin.venice.duckdb
- 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.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.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.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.heartbeat - package com.linkedin.venice.heartbeat
- 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.jobs - package com.linkedin.venice.jobs
- 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.logger - package com.linkedin.venice.logger
- com.linkedin.venice.memory - package com.linkedin.venice.memory
- 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.payload - package com.linkedin.venice.metadata.payload
- 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.protocols.controller - package com.linkedin.venice.protocols.controller
- com.linkedin.venice.pubsub - package com.linkedin.venice.pubsub
- com.linkedin.venice.pubsub.adapter - package com.linkedin.venice.pubsub.adapter
- com.linkedin.venice.pubsub.adapter.kafka - package com.linkedin.venice.pubsub.adapter.kafka
- com.linkedin.venice.pubsub.adapter.kafka.admin - package com.linkedin.venice.pubsub.adapter.kafka.admin
- com.linkedin.venice.pubsub.adapter.kafka.common - package com.linkedin.venice.pubsub.adapter.kafka.common
- com.linkedin.venice.pubsub.adapter.kafka.consumer - package com.linkedin.venice.pubsub.adapter.kafka.consumer
- com.linkedin.venice.pubsub.adapter.kafka.producer - package com.linkedin.venice.pubsub.adapter.kafka.producer
- com.linkedin.venice.pubsub.api - package com.linkedin.venice.pubsub.api
- com.linkedin.venice.pubsub.api.exceptions - package com.linkedin.venice.pubsub.api.exceptions
- com.linkedin.venice.pubsub.manager - package com.linkedin.venice.pubsub.manager
- com.linkedin.venice.pulsar.sink - package com.linkedin.venice.pulsar.sink
- com.linkedin.venice.pushmonitor - package com.linkedin.venice.pushmonitor
- com.linkedin.venice.pushstatus - package com.linkedin.venice.pushstatus
- com.linkedin.venice.pushstatushelper - package com.linkedin.venice.pushstatushelper
- com.linkedin.venice.read - package com.linkedin.venice.read
- com.linkedin.venice.read.protocol.request.router - package com.linkedin.venice.read.protocol.request.router
- com.linkedin.venice.read.protocol.response - package com.linkedin.venice.read.protocol.response
- com.linkedin.venice.read.protocol.response.streaming - package com.linkedin.venice.read.protocol.response.streaming
- com.linkedin.venice.reliability - package com.linkedin.venice.reliability
- com.linkedin.venice.request - package com.linkedin.venice.request
- com.linkedin.venice.response - package com.linkedin.venice.response
- com.linkedin.venice.router - package com.linkedin.venice.router
- com.linkedin.venice.router.acl - package com.linkedin.venice.router.acl
- com.linkedin.venice.router.api - package com.linkedin.venice.router.api
- com.linkedin.venice.router.api.path - package com.linkedin.venice.router.api.path
- com.linkedin.venice.router.api.routing.helix - package com.linkedin.venice.router.api.routing.helix
- com.linkedin.venice.router.exception - package com.linkedin.venice.router.exception
- com.linkedin.venice.router.httpclient - package com.linkedin.venice.router.httpclient
- com.linkedin.venice.router.stats - package com.linkedin.venice.router.stats
- com.linkedin.venice.router.streaming - package com.linkedin.venice.router.streaming
- com.linkedin.venice.router.throttle - package com.linkedin.venice.router.throttle
- com.linkedin.venice.router.utils - package com.linkedin.venice.router.utils
- com.linkedin.venice.routerapi - package com.linkedin.venice.routerapi
- com.linkedin.venice.samza - package com.linkedin.venice.samza
- com.linkedin.venice.schema - package com.linkedin.venice.schema
- com.linkedin.venice.schema.avro - package com.linkedin.venice.schema.avro
- com.linkedin.venice.schema.rmd - package com.linkedin.venice.schema.rmd
- com.linkedin.venice.schema.rmd.v1 - package com.linkedin.venice.schema.rmd.v1
- com.linkedin.venice.schema.vson - package com.linkedin.venice.schema.vson
- com.linkedin.venice.schema.writecompute - package com.linkedin.venice.schema.writecompute
- com.linkedin.venice.security - package com.linkedin.venice.security
- com.linkedin.venice.serialization - package com.linkedin.venice.serialization
- com.linkedin.venice.serialization.avro - package com.linkedin.venice.serialization.avro
- com.linkedin.venice.serializer - package com.linkedin.venice.serializer
- com.linkedin.venice.server - package com.linkedin.venice.server
- com.linkedin.venice.service - package com.linkedin.venice.service
- com.linkedin.venice.servicediscovery - package com.linkedin.venice.servicediscovery
- com.linkedin.venice.spark - package com.linkedin.venice.spark
- com.linkedin.venice.spark.datawriter.jobs - package com.linkedin.venice.spark.datawriter.jobs
- com.linkedin.venice.spark.datawriter.partition - package com.linkedin.venice.spark.datawriter.partition
- com.linkedin.venice.spark.datawriter.recordprocessor - package com.linkedin.venice.spark.datawriter.recordprocessor
- com.linkedin.venice.spark.datawriter.task - package com.linkedin.venice.spark.datawriter.task
- com.linkedin.venice.spark.datawriter.writer - package com.linkedin.venice.spark.datawriter.writer
- com.linkedin.venice.spark.engine - package com.linkedin.venice.spark.engine
- com.linkedin.venice.spark.input - package com.linkedin.venice.spark.input
- com.linkedin.venice.spark.input.hdfs - package com.linkedin.venice.spark.input.hdfs
- com.linkedin.venice.spark.utils - package com.linkedin.venice.spark.utils
- com.linkedin.venice.sql - package com.linkedin.venice.sql
- com.linkedin.venice.standalone - package com.linkedin.venice.standalone
- com.linkedin.venice.stats - package com.linkedin.venice.stats
- com.linkedin.venice.stats.dimensions - package com.linkedin.venice.stats.dimensions
- com.linkedin.venice.stats.metrics - package com.linkedin.venice.stats.metrics
- com.linkedin.venice.stats.routing - package com.linkedin.venice.stats.routing
- com.linkedin.venice.status - package com.linkedin.venice.status
- com.linkedin.venice.status.protocol - package com.linkedin.venice.status.protocol
- com.linkedin.venice.status.protocol.enums - package com.linkedin.venice.status.protocol.enums
- com.linkedin.venice.storage.protocol - package com.linkedin.venice.storage.protocol
- com.linkedin.venice.store - package com.linkedin.venice.store
- com.linkedin.venice.store.exception - package com.linkedin.venice.store.exception
- com.linkedin.venice.store.rocksdb - package com.linkedin.venice.store.rocksdb
- com.linkedin.venice.streaming - package com.linkedin.venice.streaming
- com.linkedin.venice.system.store - package com.linkedin.venice.system.store
- com.linkedin.venice.systemstore.schemas - package com.linkedin.venice.systemstore.schemas
- com.linkedin.venice.tehuti - package com.linkedin.venice.tehuti
- com.linkedin.venice.testng - package com.linkedin.venice.testng
- com.linkedin.venice.throttle - package com.linkedin.venice.throttle
- com.linkedin.venice.unit.kafka - package com.linkedin.venice.unit.kafka
- com.linkedin.venice.unit.kafka.consumer - package com.linkedin.venice.unit.kafka.consumer
- com.linkedin.venice.unit.kafka.consumer.poll - package com.linkedin.venice.unit.kafka.consumer.poll
- com.linkedin.venice.unit.kafka.producer - package com.linkedin.venice.unit.kafka.producer
- com.linkedin.venice.unit.matchers - package com.linkedin.venice.unit.matchers
- com.linkedin.venice.utils - package com.linkedin.venice.utils
- com.linkedin.venice.utils.collections - package com.linkedin.venice.utils.collections
- com.linkedin.venice.utils.concurrent - package com.linkedin.venice.utils.concurrent
- com.linkedin.venice.utils.consistency - package com.linkedin.venice.utils.consistency
- com.linkedin.venice.utils.lazy - package com.linkedin.venice.utils.lazy
- com.linkedin.venice.utils.locks - package com.linkedin.venice.utils.locks
- com.linkedin.venice.utils.metrics - package com.linkedin.venice.utils.metrics
- com.linkedin.venice.utils.pools - package com.linkedin.venice.utils.pools
- com.linkedin.venice.views - package com.linkedin.venice.views
- com.linkedin.venice.vpj - package com.linkedin.venice.vpj
- com.linkedin.venice.writer - package com.linkedin.venice.writer
- com.linkedin.venice.writer.update - package com.linkedin.venice.writer.update
- com.linkedin.venice.zk - package com.linkedin.venice.zk
- Command - Class in com.linkedin.venice.datarecovery
- Command - Enum Class in com.linkedin.venice
-
TODO: Merge this with
ControllerRoute
COMMAND ( "long-name", "short-name", "description", "required-args", "optional-args" ) - Command() - Constructor for class com.linkedin.venice.datarecovery.Command
- COMMAND - Enum constant in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionAction
- Command.Params - Class in com.linkedin.venice.datarecovery
- Command.Result - Class in com.linkedin.venice.datarecovery
- commandComparator - Static variable in enum class com.linkedin.venice.Command
- commandType - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
-
0 => StartConsumption, 1 => StopConsumption, 2 => KillConsumption, 3 => ResetConsumption, 4 => IsPartitionConsuming, 5 => RemoveStorageEngine, 6 => RemovePartition, 7 => OpenStorageEngine, 8 => PromoteToLeader, 9 => DemoteToStandby
- CommonConfigKeys - Class in com.linkedin.venice
-
Common config keys shared by venice-backend and venice-thin-client.
- CommonConfigKeys() - Constructor for class com.linkedin.venice.CommonConfigKeys
- commonValidityCheck() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
-
Compute operation validity check for projections, dot-product and cosine-similarity.
- compactExceptionDescription(Throwable) - Static method in class com.linkedin.venice.utils.ExceptionUtils
- compactExceptionDescription(Throwable, String) - Static method in class com.linkedin.venice.utils.ExceptionUtils
- CompactionManager - Class in com.linkedin.venice.controller.logcompaction
-
This class contains functions used by
VeniceHelixAdmin
to: 1. - CompactionManager(RepushOrchestrator, long) - Constructor for class com.linkedin.venice.controller.logcompaction.CompactionManager
- COMPARATOR - Static variable in interface org.apache.avro.generic.DeterministicMapOrderDatumWriter
- compare(byte[], byte[]) - Static method in class com.linkedin.venice.utils.ByteUtils
-
A comparator for byte arrays.
- compare(byte[], int, int, byte[], int, int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
- compare(KafkaInputMapperKey, KafkaInputMapperKey) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
- compare(KafkaInputMapperKey, KafkaInputMapperKey) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputValueGroupingComparator
- compare(Object, Object) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
-
Backport compareTo() method from SpecificRecordBase.
- compare(Object, Object, Schema) - Method in class com.linkedin.davinci.schema.merge.AvroCollectionElementComparator
-
This function compares two objects using the provided schema.
- compare(BytesWritable, BytesWritable) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputKeyComparator
- compare(Row, Row) - Method in class com.linkedin.venice.spark.datawriter.partition.PartitionSorter
- compare(T, T) - Method in class com.linkedin.venice.utils.HashCodeComparator
- COMPARE_STORE - Enum constant in enum class com.linkedin.venice.Command
- COMPARE_STORE - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- compareAndReturn(Object, Object) - Static method in class com.linkedin.davinci.replication.merge.MergeUtils
- compareAndUpdate(ZkBaseDataAccessor<T>, String, int, DataUpdater<T>) - Static method in class com.linkedin.venice.utils.HelixUtils
- compareAndUpdate(ZkBaseDataAccessor<T>, String, DataUpdater<T>) - Static method in class com.linkedin.venice.utils.HelixUtils
- compareGenericData(Object, Object, Schema) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
-
Backport compare() method implementation from GenericData in avro v1.7
- compareObjectToDefaultValue(Object, Schema, String, Object) - Static method in class com.linkedin.venice.controller.kafka.protocol.serializer.SemanticDetector
-
Validate the object with default value.
- comparePosition(VeniceChangeCoordinate) - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
- comparePubSubPositions(PubSubPosition, PubSubPosition) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
-
Compares two
PubSubPosition
instances by their symbolic or numeric ordering. - compareSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
- compareSchema(Schema, Schema) - Method in interface com.linkedin.venice.controller.supersetschema.SupersetSchemaGenerator
-
Compare whether two schemas are equal or not with the consideration of superset schema.
- compareSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
- compareSchemaIgnoreFieldOrder(Schema, Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
-
Compares two schema with possible re-ordering of the fields.
- compareSpecificData(Object, Object, Schema) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
-
Backport compare() method implementation from SpecificData in avro v1.7
- compareStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- compareStore(String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- compareStore(String, String, String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Compare store metadata and version states between two fabrics.
- compareStore(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- compareStore(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- compareTo(ConsumerAction) - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- compareTo(ByteArrayKey) - Method in class com.linkedin.davinci.utils.ByteArrayKey
- compareTo(Version) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- compareTo(Version) - Method in class com.linkedin.venice.meta.VersionImpl
- compareTo(PartitionStatus) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
- compareTo(RouterKey) - Method in class com.linkedin.venice.router.api.RouterKey
- compareTo(Channel) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- compareUnsigned(byte[], byte[]) - Static method in class com.linkedin.venice.utils.ArrayUtils
-
This is mostly a copy of Arrays.compareUnsigned(T[], T[]) from Java 9.
- COMPATIBLE - Enum constant in enum class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaCompatibilityType
- ComplementSet<T> - Class in com.linkedin.venice.utils
-
A set that uses complement representation, which is useful when universal set cardinality is unknown.
- ComplementSet(boolean, Set<T>) - Constructor for class com.linkedin.venice.utils.ComplementSet
- CompletableFutureCallback - Class in com.linkedin.venice.writer
-
Compose a CompletableFuture and Callback together to be a
CompletableFutureCallback
type. - CompletableFutureCallback(CompletableFuture<Void>) - Constructor for class com.linkedin.venice.writer.CompletableFutureCallback
- complete(Promise<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
- complete(Promise<V>, Consumer<V>) - Static method in class com.linkedin.alpini.netty4.misc.Futures
- complete(T) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
- COMPLETE_MIGRATION - Enum constant in enum class com.linkedin.venice.Command
- COMPLETE_MIGRATION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- completeCoreWorkWithError(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
- completeCoreWorkWithMessage(String) - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
- completed(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
-
Consumption is completed for a store and partition.
- completed(String, int, long, String) - Method in class com.linkedin.davinci.helix.StateModelIngestionProgressNotifier
- completed(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
- completed(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
- completed(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
- completed(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
- completed(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
- COMPLETED - Enum constant in enum class com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
- COMPLETED - Enum constant in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
- COMPLETED - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
For task, data is read and put into storage engine.
- COMPLETED - Enum constant in enum class com.linkedin.venice.status.PushJobDetailsStatus
- completeExceptionally(Throwable) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
- completeFuture(int, int, CompressionStrategy, byte[]) - Method in class com.linkedin.venice.client.store.transport.TransportClientCallback
- COMPLETELY_UPDATED - Enum constant in enum class com.linkedin.davinci.schema.merge.UpdateResultStatus
- completeMigration(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- completeMigration(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- completeMigration(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
- completeMigration(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- completeMigration(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- completePersistedToDBFuture(Exception) - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- completionReported - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Whether completion has been reported before
- completionReported() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- COMPLEX - Enum constant in enum class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator.Mode
- COMPLEX - Enum constant in enum class com.linkedin.venice.partitioner.VenicePartitioner.VenicePartitionerType
- ComplexAccumulator<T,
A, R> - Class in com.linkedin.alpini.base.concurrency -
One or more variables that together maintain an accumulation.
- ComplexAccumulator(Collector<T, A, R>) - Constructor for class com.linkedin.alpini.base.concurrency.ComplexAccumulator
- complexDelete(K, Lazy<GenericRecord>) - Method in class com.linkedin.venice.writer.ComplexVeniceWriter
-
Perform "delete" on the given key.
- complexPut(K, V, int, Lazy<GenericRecord>) - Method in class com.linkedin.venice.writer.ComplexVeniceWriter
- complexPut(K, V, int, Lazy<GenericRecord>, Consumer<int[]>, PubSubProducerCallback, PutMetadata) - Method in class com.linkedin.venice.writer.ComplexVeniceWriter
-
ComplexVenicePartitioner
offers a more sophisticated getPartitionId API. - ComplexVenicePartitioner - Class in com.linkedin.venice.partitioner
-
Determines partitioning but offers more complex partitioning API that could partition not just based on "immutable" fields of the value.
- ComplexVenicePartitioner() - Constructor for class com.linkedin.venice.partitioner.ComplexVenicePartitioner
- ComplexVenicePartitioner(VeniceProperties) - Constructor for class com.linkedin.venice.partitioner.ComplexVenicePartitioner
- ComplexVenicePartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.partitioner.ComplexVenicePartitioner
- ComplexVeniceWriter<K,
V, U> - Class in com.linkedin.venice.writer -
Provide more complex and sophisticated writer APIs for writing to
MaterializedView
. - ComplexVeniceWriter(VeniceWriterOptions, VeniceProperties, PubSubProducerAdapter) - Constructor for class com.linkedin.venice.writer.ComplexVeniceWriter
- componentType - Variable in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
-
0 => KafkaIngestionService, 1 => StorageService
- composeKafkaTopic(String, int) - Static method in interface com.linkedin.venice.meta.Version
- composePartitionDbDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeRealTimeTopic(String) - Static method in class com.linkedin.venice.utils.Utils
-
This method should only be used for system stores.
- composeRealTimeTopic(String, int) - Static method in class com.linkedin.venice.utils.Utils
- composeRegionList(Set<String>) - Static method in class com.linkedin.venice.utils.RegionUtils
-
A helper function to compose a region list with
RegionUtils.REGION_FILTER_LIST_SEPARATOR
. - composeRouterRequest(String) - Method in class com.linkedin.venice.router.api.path.VenicePath
- composeRouterRequestInternal(String) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- composeRouterRequestInternal(String) - Method in class com.linkedin.venice.router.api.path.VenicePath
- composeRouterRequestInternal(String) - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- composeSnapshotDir(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeSnapshotDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeStoreDbDir(String, String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeStreamReprocessingTopic(String, int) - Static method in interface com.linkedin.venice.meta.Version
- composeStreamReprocessingTopicFromVersionTopic(String) - Static method in interface com.linkedin.venice.meta.Version
- composeTempRMDSSTFileDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeTempRMDSSTFileName(int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeTempSSTFileDir(String, String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeTempSSTFileName(int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- composeTopicName(int) - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
- composeTopicName(int) - Method in class com.linkedin.venice.views.ChangeCaptureView
- composeTopicName(int) - Method in class com.linkedin.venice.views.MaterializedView
- composeTopicName(int) - Method in class com.linkedin.venice.views.VeniceView
- composeVersionTopicFromStreamReprocessingTopic(String) - Static method in interface com.linkedin.venice.meta.Version
- CompositePollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
-
A
PollStrategy
implementation which takes a queue of many poll strategies. - CompositePollStrategy(Queue<AbstractPollStrategy>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.CompositePollStrategy
- CompositePredicate<T> - Class in com.linkedin.venice.client.store.predicate
- CompositeVeniceWriter<K,
V, U> - Class in com.linkedin.venice.hadoop.task.datawriter -
The composite writer contains a main writer and multiple child writers.
- CompositeVeniceWriter(String, VeniceWriter<K, V, U>, ComplexVeniceWriter<K, V, U>[], PubSubProducerCallback, BiFunction<V, Integer, GenericRecord>) - Constructor for class com.linkedin.venice.hadoop.task.datawriter.CompositeVeniceWriter
- compress(byte[]) - Method in class com.linkedin.venice.compression.NoopCompressor
- compress(byte[]) - Method in class com.linkedin.venice.compression.VeniceCompressor
- compress(byte[]) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
- compress(ByteBuffer, int) - Method in class com.linkedin.venice.compression.NoopCompressor
- compress(ByteBuffer, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
- compressedValueSizeCounter - Variable in class com.linkedin.venice.spark.datawriter.task.DataWriterAccumulators
- compressInternal(byte[]) - Method in class com.linkedin.venice.compression.GzipCompressor
- compressInternal(byte[]) - Method in class com.linkedin.venice.compression.NoopCompressor
- compressInternal(byte[]) - Method in class com.linkedin.venice.compression.VeniceCompressor
- compressInternal(byte[]) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- compressInternal(ByteBuffer, int) - Method in class com.linkedin.venice.compression.GzipCompressor
- compressInternal(ByteBuffer, int) - Method in class com.linkedin.venice.compression.NoopCompressor
- compressInternal(ByteBuffer, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
- compressInternal(ByteBuffer, int) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- COMPRESSION_DICTIONARY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- COMPRESSION_DICTIONARY_SAMPLE_SIZE - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
Sample size to collect for building dictionary: Can be assigned a max of 2GB as
ZstdDictTrainer
in ZSTD library takes in sample size as int - COMPRESSION_DICTIONARY_SIZE_LIMIT - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
Maximum final dictionary size TODO add more details about the current limits
- COMPRESSION_METRIC_COLLECTION_ENABLED - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
Config to enable/disable the feature to collect extra metrics wrt compression.
- COMPRESSION_STRATEGIES - Static variable in class com.linkedin.venice.utils.DataProviderUtils
- COMPRESSION_STRATEGY - Enum constant in enum class com.linkedin.venice.Arg
- COMPRESSION_STRATEGY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- COMPRESSION_STRATEGY - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- compressionDictionary - Variable in class com.linkedin.venice.kafka.protocol.StartOfPush
-
The raw bytes of dictionary used to compress/decompress records.
- compressionDictionary - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
The raw bytes of dictionary used to compress/decompress records.
- compressionMetricCollectionEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- compressionProvider() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- compressionStrategy - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- compressionStrategy - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Using int because Avro Enums are not evolvable
- compressionStrategy - Variable in class com.linkedin.venice.kafka.protocol.StartOfPush
-
What type of compression strategy the current push uses.
- compressionStrategy - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
What type of compression strategy the current push are used.
- compressionStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- compressionStrategy - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
- compressionStrategy - Variable in class com.linkedin.venice.metadata.response.VersionProperties
-
The current version's compression strategy.
- compressionStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Strategy used to compress/decompress Record's value, and default is 'NO_OP'
- compressionStrategy - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
strategies used to compress/decompress Record's value, and default is 'NO_OP'
- CompressionStrategy - Enum Class in com.linkedin.venice.compression
-
Enums of the strategies used to compress/decompress Record's value
- COMPRESSIONSTRATEGY_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
- compressor - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- compressorFactory - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- compressorFactory - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- CompressorFactory - Class in com.linkedin.venice.compression
- CompressorFactory() - Constructor for class com.linkedin.venice.compression.CompressorFactory
- compressorMap - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- compute() - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
- compute() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
-
This API allows performing transformations (projection, vector arithmetic and aggregations like count) on the values associated with the given set of keys.
- compute() - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
- compute(int, byte[], AbstractAvroChunkingAdapter<GenericRecord>, AvroStoreDeserializerCache<GenericRecord>, int, BinaryDecoder, ByteBuffer, GenericRecord, Map<String, Object>, ComputeRequestWrapper, Schema) - Method in class com.linkedin.davinci.VersionBackend
- compute(int, int, IntFunction<ComputeResponseWrapper>) - Static method in class com.linkedin.venice.listener.response.ParallelMultiKeyResponseWrapper
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.AvroBlackHoleResponseStoreClientImpl
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
- compute(ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
- compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
- compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.CountOperator
- compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.DotProductOperator
- compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in class com.linkedin.venice.compute.HadamardProductOperator
- compute(ComputeOperation, Schema.Field, Schema.Field, GenericRecord, GenericRecord, Map<String, String>, Map<String, Object>) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
- compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
- compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.LoadControlledAvroGenericStoreClient
- compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.RetriableAvroGenericStoreClient
- compute(ComputeRequestContext<K, V>, ComputeRequestWrapper, Set<K>, Schema, StreamingCallback<K, ComputeGenericRecord>, long) - Method in class com.linkedin.venice.fastclient.StatsAvroGenericStoreClient
- compute(Optional<ClientStats>, AvroGenericReadComputeStoreClient) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- compute(Optional<ClientStats>, AvroGenericReadComputeStoreClient) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
- compute(Optional<ClientStats>, AvroGenericReadComputeStoreClient) - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
-
Deprecated.
- compute(Optional<ClientStats>, Optional<ClientStats>, long) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
-
Deprecated.
- compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
-
Deprecated.
- compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long) - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
- COMPUTE - Enum constant in enum class com.linkedin.venice.meta.QueryAction
- COMPUTE - Enum constant in enum class com.linkedin.venice.read.RequestType
- COMPUTE_REQUEST_CLIENT_KEY_V1 - Enum constant in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
-
Compute request client key v1.
- COMPUTE_REQUEST_V1 - Enum constant in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
-
Compute request v1.
- COMPUTE_REQUEST_V2 - Enum constant in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
-
Compute request v2.
- COMPUTE_REQUEST_V3 - Enum constant in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
-
Compute request v3.
- COMPUTE_REQUEST_V4 - Enum constant in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
-
Compute request v4.
- COMPUTE_REQUEST_VERSION_V2 - Static variable in class com.linkedin.venice.VeniceConstants
-
Compute request version 2.
- COMPUTE_REQUEST_VERSION_V3 - Static variable in class com.linkedin.venice.VeniceConstants
-
V3 contains all V2 operator + new Count operator
- COMPUTE_REQUEST_VERSION_V4 - Static variable in class com.linkedin.venice.VeniceConstants
-
V4 contains all V3 operators + executeWithFilter
- COMPUTE_RESPONSE_V1 - Enum constant in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
-
Response record for compute v1
- COMPUTE_ROUTER_REQUEST_V1 - Enum constant in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
-
Router request key for read compute v1.
- COMPUTE_STREAMING - Enum constant in enum class com.linkedin.venice.read.RequestType
- COMPUTE_VALID_HEADER_MAP - Static variable in class com.linkedin.venice.router.api.VeniceResponseAggregator
- ComputeAggregationRequestBuilder<K> - Interface in com.linkedin.venice.client.store
- ComputeAggregationResponse - Interface in com.linkedin.venice.client.store
- computedAggregates - Variable in class com.linkedin.venice.kafka.protocol.EndOfSegment
-
A map containing the results of the aggregate computation strategies that were promised in the previous StartOfSegment ControlMessage.
- ComputeGenericRecord - Class in com.linkedin.venice.client.store
-
A simple wrapper to throw exception when retrieving failed computation.
- ComputeGenericRecord(GenericRecord, Schema) - Constructor for class com.linkedin.venice.client.store.ComputeGenericRecord
-
Schema of the original record that was used to compute the result
- computeIfAbsent(int, IntFunction<? extends E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
- computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class com.linkedin.venice.utils.concurrent.VeniceConcurrentHashMap
-
TODO: Remove this class once the code has completely migrated to JDK11+ The native `computeIfAbsent` function implemented in Java could have contention when the value already exists
ConcurrentHashMap.computeIfAbsent(Object, Function)
; the contention could become very bad when lots of threads are trying to "computeIfAbsent" on the same key, which is a known Java bug: https://bugs.openjdk.java.net/browse/JDK-8161372 This internal VeniceConcurrentHashMap mitigate such contention by trying to get the value first before invoking "computeIfAbsent", which brings great optimization if the major workload is trying to get the same key over and over again; however, we speculate that this optimization might not be ideal for the workload that most keys are unique, so be cautious about the workload before adopting the VeniceConcurrentHashMap. - computeIfNotNull(T, Consumer<T>) - Static method in class com.linkedin.venice.utils.Utils
-
Run "function" on "t" if "t" is not null
- computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
- ComputeJob - Interface in com.linkedin.venice.jobs
-
An interface to abstract executing and monitoring a compute job running on any batch compute engine
- ComputeJob.Status - Enum Class in com.linkedin.venice.jobs
- ComputeOperation - Class in com.linkedin.venice.compute.protocol.request
- ComputeOperation() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeOperation
-
Default constructor.
- ComputeOperation(Integer, Object) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeOperation
-
All-args constructor.
- ComputeOperationType - Enum Class in com.linkedin.venice.compute.protocol.request.enums
- ComputeRecordStreamDecoder<K,
V> - Class in com.linkedin.venice.client.store.streaming - ComputeRecordStreamDecoder(List<K>, TrackingStreamingCallback<K, V>, Executor, RecordDeserializer<StreamingFooterRecordV1>, RecordDeserializer<V>) - Constructor for class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
- ComputeRequest - Class in com.linkedin.venice.compute.protocol.request
-
This record only contains the operations and result schema, and keys will be appended after during serialization
- ComputeRequest() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequest
-
Default constructor.
- ComputeRequest(List<ComputeOperation>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequest
-
All-args constructor.
- ComputeRequestBuilder<K> - Interface in com.linkedin.venice.client.store
- computeRequestClientKeySerializer - Variable in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- ComputeRequestContext<K,
V> - Class in com.linkedin.venice.fastclient -
Keep track of the progress of a compute request .
- ComputeRequestContext(int, boolean) - Constructor for class com.linkedin.venice.fastclient.ComputeRequestContext
- ComputeRequestV1 - Class in com.linkedin.venice.compute.protocol.request
-
This record only contains the operations and result schema, and keys will be appended after during serialization
- ComputeRequestV1() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
-
Default constructor.
- ComputeRequestV1(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
-
All-args constructor.
- ComputeRequestV2 - Class in com.linkedin.venice.compute.protocol.request
-
This record only contains the operations and result schema, and keys will be appended after during serialization
- ComputeRequestV2() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
-
Default constructor.
- ComputeRequestV2(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
-
All-args constructor.
- ComputeRequestV3 - Class in com.linkedin.venice.compute.protocol.request
-
This record only contains the operations and result schema, and keys will be appended after during serialization
- ComputeRequestV3() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
-
Default constructor.
- ComputeRequestV3(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
-
All-args constructor.
- ComputeRequestV4 - Class in com.linkedin.venice.compute.protocol.request
-
This record only contains the operations and result schema, and keys will be appended after during serialization
- ComputeRequestV4() - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
-
Default constructor.
- ComputeRequestV4(List<Object>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
-
All-args constructor.
- ComputeRequestWrapper - Class in com.linkedin.venice.compute
-
This class is used by the client to encapsulate the information it needs about a compute request.
- ComputeRequestWrapper(int, Schema, Schema, String, List<ComputeOperation>, boolean) - Constructor for class com.linkedin.venice.compute.ComputeRequestWrapper
- ComputeResponseRecordV1 - Class in com.linkedin.venice.compute.protocol.response
-
This record used to store the response per key
- ComputeResponseRecordV1() - Constructor for class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
-
Default constructor.
- ComputeResponseRecordV1(Integer, ByteBuffer) - Constructor for class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
-
All-args constructor.
- ComputeResponseRecordV1ChunkedDeserializer - Class in com.linkedin.venice.client.store.streaming
- ComputeResponseRecordV1ChunkedDeserializer() - Constructor for class com.linkedin.venice.client.store.streaming.ComputeResponseRecordV1ChunkedDeserializer
- ComputeResponseStats - Class in com.linkedin.venice.listener.response.stats
- ComputeResponseStats() - Constructor for class com.linkedin.venice.listener.response.stats.ComputeResponseStats
- ComputeResponseStatsWithSizeProfiling - Class in com.linkedin.venice.listener.response.stats
- ComputeResponseStatsWithSizeProfiling(int) - Constructor for class com.linkedin.venice.listener.response.stats.ComputeResponseStatsWithSizeProfiling
- ComputeResponseWrapper - Class in com.linkedin.venice.listener.response
- ComputeResponseWrapper(int) - Constructor for class com.linkedin.venice.listener.response.ComputeResponseWrapper
- ComputeResponseWrapper(int, ComputeResponseStats) - Constructor for class com.linkedin.venice.listener.response.ComputeResponseWrapper
- computeResult(List<ComputeOperation>, List<Schema.Field>, Map<String, Object>, GenericRecord, GenericRecord) - Static method in class com.linkedin.venice.compute.ComputeUtils
- computeResult(List<ComputeOperation>, List<Schema.Field>, Map<String, Object>, GenericRecord, Schema) - Static method in class com.linkedin.venice.compute.ComputeUtils
- ComputeRouterRequestKeyV1 - Class in com.linkedin.venice.compute.protocol.request.router
-
This field will store all the related info for one key
- ComputeRouterRequestKeyV1() - Constructor for class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
-
Default constructor.
- ComputeRouterRequestKeyV1(Integer, ByteBuffer, Integer) - Constructor for class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
-
All-args constructor.
- ComputeRouterRequestWrapper - Class in com.linkedin.venice.listener.request
-
ComputeRouterRequestWrapper
encapsulates a POST request for read-compute from routers. - computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
- computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
- computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in interface com.linkedin.davinci.storage.StorageMetadataService
- computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
- computeStoreVersionState(String, Function<StoreVersionState, StoreVersionState>) - Method in class com.linkedin.venice.offsets.InMemoryStorageMetadataService
- ComputeUtils - Class in com.linkedin.venice.compute
-
This class provides utilities for float-vector operations, and it also handles
PrimitiveFloatList
transparently to the user of this class. - ComputeUtils() - Constructor for class com.linkedin.venice.compute.ComputeUtils
- computeWithKeyPrefixFilter(byte[], int, StreamingCallback<GenericRecord, GenericRecord>, ComputeRequestWrapper, AbstractAvroChunkingAdapter<GenericRecord>, RecordDeserializer<GenericRecord>, GenericRecord, BinaryDecoder, Map<String, Object>, Schema) - Method in class com.linkedin.davinci.VersionBackend
- computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
- computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
- computeWithKeyPrefixFilter(byte[], ComputeRequestWrapper, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
- concat(Iterator<T>...) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
- ConcurrencyUtils - Class in com.linkedin.venice.utils.concurrent
- CONCURRENT_BATCH_PUSH - Enum constant in enum class com.linkedin.venice.exceptions.ErrorType
- CONCURRENT_BATCH_PUSH - Enum constant in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
CONCURRENT_BATCH_PUSH = 9;
- CONCURRENT_BATCH_PUSH - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- CONCURRENT_BATCH_PUSH_VALUE - Static variable in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
CONCURRENT_BATCH_PUSH = 9;
- CONCURRENT_INIT_ROUTINES_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Enable the concurrent execution of the controllers' init routines, which are executed when a controller becomes a cluster leader.
- ConcurrentAccumulator<T,
A, R> - Class in com.linkedin.alpini.base.concurrency -
One or more variables that together maintain an accumulation.
- ConcurrentAccumulator(ConcurrentAccumulator.Mode, Collector<T, A, R>) - Constructor for class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
- ConcurrentAccumulator(Collector<T, A, R>) - Constructor for class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
- ConcurrentAccumulator.Mode - Enum Class in com.linkedin.alpini.base.concurrency
- ConcurrentBatchPushException - Exception in com.linkedin.venice.exceptions
- ConcurrentBatchPushException(String) - Constructor for exception com.linkedin.venice.exceptions.ConcurrentBatchPushException
- ConcurrentRef<T> - Class in com.linkedin.venice.utils
- ConcurrentRef(Consumer<T>) - Constructor for class com.linkedin.venice.utils.ConcurrentRef
- ConcurrentRef(T, Consumer<T>) - Constructor for class com.linkedin.venice.utils.ConcurrentRef
- config - Variable in enum class com.linkedin.venice.utils.ValueSize
- config() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- Config() - Constructor for class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- CONFIG_DIRECTORY - Static variable in class com.linkedin.davinci.config.StoreBackendConfig
- ConfigConstants - Class in com.linkedin.venice
- ConfigConstants() - Constructor for class com.linkedin.venice.ConfigConstants
- ConfigEntity(String, T, String) - Constructor for class com.linkedin.venice.utils.Utils.ConfigEntity
- ConfigKeys - Class in com.linkedin.venice
- configMap - Variable in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
-
A map that contains all the configs in runtime
- configs - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- configs - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
- ConfigurationException - Exception in com.linkedin.venice.exceptions
-
Thrown when a config property is invalid or missing
- ConfigurationException(Exception) - Constructor for exception com.linkedin.venice.exceptions.ConfigurationException
- ConfigurationException(String) - Constructor for exception com.linkedin.venice.exceptions.ConfigurationException
- ConfigurationException(String, Exception) - Constructor for exception com.linkedin.venice.exceptions.ConfigurationException
- configure(EngineTaskConfigProvider) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
-
Configures the task with the given
EngineTaskConfigProvider
. - configure(VeniceProperties) - Method in interface com.linkedin.venice.jobs.ComputeJob
- configure(VeniceProperties) - Method in class com.linkedin.venice.jobs.DataWriterComputeJob
- configure(VeniceProperties, PushJobSetting) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
- configure(VeniceProperties, PushJobSetting) - Method in class com.linkedin.venice.jobs.DataWriterComputeJob
- configure(VeniceProperties, PushJobSetting) - Method in class com.linkedin.venice.spark.datawriter.jobs.AbstractDataWriterSparkJob
- configure(String, VeniceProperties, MetricsRepository, SchemaReader, SchemaReader) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
- configure(Map<String, ?>) - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
- configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.DefaultSerializer
- configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.KafkaKeySerializer
- configure(Map<String, ?>, boolean) - Method in class com.linkedin.venice.serialization.StringSerializer
-
Configure this class.
- configure(Map<String, ?>, boolean) - Method in interface com.linkedin.venice.serialization.VeniceKafkaSerializer
-
Configure this class.
- configure(Schema, Schema) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
-
Configure the record serializers
- configure(JobConf) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormatCombiner
- configure(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.map.AbstractVeniceMapper
- configure(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
- configure(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- CONFIGURE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- CONFIGURE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- CONFIGURE_INCREMENTAL_PUSH_FOR_CLUSTER - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
-
Deprecated.We do not support incremental push policy anymore.
- CONFIGURE_NATIVE_REPLICATION_FOR_CLUSTER - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- CONFIGURE_STORE_VIEW - Enum constant in enum class com.linkedin.venice.Command
- configureActiveActiveReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
-
Enable/disable active active replications for certain stores (batch only, hybrid only, incremental push, hybrid or incremental push, all) in a cluster.
- configureActiveActiveReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- configureActiveActiveReplication(String, VeniceUserStoreType, Optional<String>, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- configureActiveActiveReplicationForCluster(boolean, String, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- ConfigureActiveActiveReplicationForCluster - Class in com.linkedin.venice.controller.kafka.protocol.admin
- ConfigureActiveActiveReplicationForCluster() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
-
Default constructor.
- ConfigureActiveActiveReplicationForCluster(CharSequence, CharSequence, Boolean, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
-
All-args constructor.
- ConfigureIncrementalPushForCluster - Class in com.linkedin.venice.controller.kafka.protocol.admin
-
A command to migrate all incremental push stores in a cluster to a specific incremental push policy.
- ConfigureIncrementalPushForCluster() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
-
Default constructor.
- ConfigureIncrementalPushForCluster(CharSequence, Integer, Integer, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
-
All-args constructor.
- ConfigureNativeReplicationForCluster - Class in com.linkedin.venice.controller.kafka.protocol.admin
- ConfigureNativeReplicationForCluster() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
-
Default constructor.
- ConfigureNativeReplicationForCluster(CharSequence, CharSequence, Boolean, CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
-
All-args constructor.
- configurePipeline(ChannelHandlerContext, String) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
- configureSourceFabric(Admin, Version, Lazy<Boolean>, RequestTopicForPushRequest, VersionCreationResponse) - Method in class com.linkedin.venice.controller.server.CreateVersion
-
Configures the source fabric to align with the native replication source fabric selection.
- configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormatCombiner
- configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
- configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
- configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
-
Allow implementations of this class to configure task-specific stuff.
- configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
- configureTask(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
- configureWebSockets(Map<String, WebSocketHandlerWrapper>, Optional<Long>) - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
- confirmStores(Set<String>) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
- CONFLICT - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- connect() - Method in class com.linkedin.venice.helix.SafeHelixManager
- connect(SocketAddress) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- connect(SocketAddress, ChannelPromise) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- connect(SocketAddress, SocketAddress) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- connect(SocketAddress, SocketAddress, ChannelPromise) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- CONNECTED - Enum constant in enum class com.linkedin.venice.meta.InstanceStatus
- connectHelixManager(SafeHelixManager, int, int) - Static method in class com.linkedin.venice.utils.HelixUtils
-
Try to connect Helix Manger.
- CONNECTION_ERROR - Enum constant in enum class com.linkedin.venice.exceptions.ErrorType
- CONNECTION_ERROR - Enum constant in enum class com.linkedin.venice.exceptions.ExceptionType
-
Deprecated.
- CONNECTION_ERROR - Enum constant in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
CONNECTION_ERROR = 6;
- CONNECTION_ERROR_VALUE - Static variable in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
CONNECTION_ERROR = 6;
- connectionChannel(ChannelHandlerContext) - Static method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
- ConnectionControlHandler - Class in com.linkedin.alpini.netty4.handlers
-
A
ChannelHandler
which regulates the number of open connections by disabling the parent socket auto-read config when the number of active connections exceeds the limit value. - ConnectionControlHandler(IntSupplier, Consumer<Integer>, Consumer<Integer>) - Constructor for class com.linkedin.alpini.netty4.handlers.ConnectionControlHandler
- connectionCountRecorder(Consumer<Integer>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
- connectionCountRecorder(Consumer<Integer>) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
- connectionHandleMode(ConnectionHandleMode) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
- connectionHandleMode(ConnectionHandleMode) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
- ConnectionHandleMode - Enum Class in com.linkedin.alpini.netty4.handlers
- connectionLimit(int) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
-
Allow 0 limit to reject all connections as well as testing.
- connectionLimit(int) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
- connectionLimit(IntSupplier) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
- connectionLimit(IntSupplier) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
- ConnectionLimitHandler - Class in com.linkedin.alpini.netty4.handlers
- ConnectionLimitHandler(IntSupplier, Consumer<Integer>, Consumer<Integer>) - Constructor for class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
-
Construct with a preset connection limit.
- connectionScheme(ChannelHandlerContext) - Static method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
- connectionSchemeAttribute(ChannelHandlerContext) - Static method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
- CONSISTENT_HASH - Enum constant in enum class com.linkedin.venice.meta.RoutingStrategy
- CONSTANT_PARTITION - Static variable in class com.linkedin.venice.partitioner.ConstantVenicePartitioner
- Constants() - Constructor for class com.linkedin.venice.kafka.protocol.enums.MessageType.Constants
- ConstantVenicePartitioner - Class in com.linkedin.venice.partitioner
- ConstantVenicePartitioner(VeniceProperties) - Constructor for class com.linkedin.venice.partitioner.ConstantVenicePartitioner
- ConstantVenicePartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.partitioner.ConstantVenicePartitioner
- constructChunksContainer(ChunkedValueManifest) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
- constructChunksContainer(ChunkedValueManifest) - Method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
- constructChunksContainer(ChunkedValueManifest) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
-
Used to construct the right kind of container (according to the query code) to hold a large value which needs to be incrementally re-assembled from many smaller chunks.
- constructChunksContainer(ChunkedValueManifest) - Method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
- constructClusterControllerClient(String, String) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
- constructClusterControllerClient(String, String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
- constructHttpClusterDiscoveryResponse(String, String, String) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructHttpMultiSchemaIdResponse(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructHttpMultiSchemaResponse(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructHttpSchemaResponse(String, int, String) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructInputDataInfoProvider() - Method in class com.linkedin.venice.hadoop.VenicePushJob
- constructMultiSchemaIdResponseInBytes(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructMultiSchemaResponseInBytes(String, Map<Integer, String>) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructRouterPipelineFactory(ScatterGatherRequestHandler4<H, P, K, R>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- constructSchemaResponseInBytes(String, int, String) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructShutdown(SyncShutdownable) - Method in class com.linkedin.alpini.base.registry.SyncShutdownableAdapter
- constructShutdown(R) - Method in class com.linkedin.alpini.base.registry.AbstractShutdownableResource
-
The constructed runnable must call
AbstractShutdownableResource.signalShutdownInitiated()
method to indicate that shutdown has started. - constructStoreResponse(int, byte[]) - Static method in class com.linkedin.venice.client.utils.StoreClientTestUtils
- constructValue(byte[], int, int, RecordDeserializer<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
- constructValue(byte[], int, int, RecordDeserializer<VALUE>, VeniceCompressor) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
- constructValue(byte[], int, T, BinaryDecoder, ReadResponseStats, int, int, StoreDeserializerCache<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
- constructValue(byte[], int, VALUE, BinaryDecoder, ReadResponseStats, int, int, StoreDeserializerCache<VALUE>, VeniceCompressor) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
-
Used to wrap a small value fetched from the storage engine into the right type of class needed by the query code.
- constructValue(int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
- constructValue(int, byte[]) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
-
This function can be implemented by the adapters which need fewer parameters.
- constructValue(int, byte[]) - Method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
- constructValue(int, CHUNKS_CONTAINER) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
-
This function can be implemented by the adapters which need fewer parameters.
- constructValue(int, CompositeByteBuf) - Method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
- constructValue(int, ByteBuffer) - Method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
- constructValue(CHUNKS_CONTAINER, VALUE, BinaryDecoder, ReadResponseStats, int, int, StoreDeserializerCache<VALUE>, VeniceCompressor) - Method in interface com.linkedin.davinci.storage.chunking.ChunkingAdapter
-
Used to wrap a large value re-assembled with the use of a into the right type of class needed by the query code.
- constructValue(ChunkedValueInputStream, T, BinaryDecoder, ReadResponseStats, int, int, StoreDeserializerCache<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
- constructVeniceWriter(VeniceWriterFactory, String, Version, boolean, int) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- constructVeniceWriter(Properties, VeniceWriterOptions) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
- consume() - Method in class com.linkedin.venice.client.store.streaming.ReadEnvelopeChunkedDeserializer
- consume(String, int, long) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
- CONSUMED_RECORD_END_TO_END_PROCESSING_LATENCY - Static variable in class com.linkedin.davinci.stats.IngestionStats
- consumedBytesSinceLastSync - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Map of broker URL to the total bytes consumed by ConsumptionTask since the last Global RT DIV sync
- ConsumedDataReceiver<MESSAGE> - Interface in com.linkedin.davinci.ingestion.consumption
-
An abstraction of a receiver of data consumed from a message queue.
- consumedFromUpstream - Variable in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatTimeStampEntry
-
Whether this heartbeat entry was consumed from input or if the system initialized it as a default entry
- consumeDoubleAndBooleanIfAbove(DoubleAndBooleanConsumer, double, boolean, double) - Static method in class com.linkedin.venice.listener.response.stats.ResponseStatsUtil
- consumeDoubleIfAbove(DoubleConsumer, double, double) - Static method in class com.linkedin.venice.listener.response.stats.ResponseStatsUtil
- consumeIntIfAbove(IntConsumer, int, int) - Static method in class com.linkedin.venice.listener.response.stats.ResponseStatsUtil
- CONSUMER - Enum constant in enum class com.linkedin.venice.pubsub.PubSubClientType
- CONSUMER_METRIC_ENTITIES - Static variable in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
- ConsumerAction - Class in com.linkedin.davinci.kafka.consumer
-
The class is used to asynchronously trigger behavior changes in the
StoreIngestionTask
. - ConsumerAction(ConsumerActionType, PubSubTopicPartition, int, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerAction
- ConsumerAction(ConsumerActionType, PubSubTopicPartition, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker, boolean) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerAction
- consumerActionSequenceNumber - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- consumerActionsQueue - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- ConsumerActionType - Enum Class in com.linkedin.davinci.kafka.consumer
-
An Enum enumerating all valid types of
ConsumerAction
. - consumerBatchUnsubscribe(Set<PubSubTopicPartition>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- consumerDiv - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
The consumer and drainer DIV must remain separate.
- consumeRemotely - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Whether the node is consuming remotely for this partition
- consumeRemotely() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- consumerHasAnySubscription() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- consumerHasSubscription(PubSubTopic, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- consumerPollTracker - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- ConsumerPollTracker - Class in com.linkedin.davinci.kafka.consumer
-
This class maintains a map of all the subscribed topic partitions and the timestamp when it was subscribed.
- ConsumerPollTracker(Time) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerPollTracker
- ConsumerPoolStrategy() - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategy
- ConsumerPoolType - Enum Class in com.linkedin.davinci.kafka.consumer
- consumerResetOffset(PubSubTopic, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- consumerServices - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategy
- consumerSubscribe(PubSubTopicPartition, long, String) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
-
Ensures the PubSub URL is present in the PubSub cluster URL-to-ID map before subscribing to a topic.
- consumerSubscribe(PubSubTopic, PartitionConsumptionState, long, String) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
This method will try to resolve actual topic-partition from input Kafka URL and subscribe to the resolved topic-partition.
- ConsumerSubscriptionCleaner - Class in com.linkedin.davinci.kafka.consumer
-
Encapsulates the logic for deciding if a given topic-partition should be unsubscribed and, in that case, executing the unsubscription.
- ConsumerSubscriptionCleaner(long, int, StaleTopicChecker, Supplier<Set<PubSubTopicPartition>>, IntConsumer, Consumer<Set<PubSubTopicPartition>>, Time) - Constructor for class com.linkedin.davinci.kafka.consumer.ConsumerSubscriptionCleaner
- consumerToConsumptionTask - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- consumerToLocks - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
-
This read-only per consumer lock is for protecting the partition unsubscription and data receiver setting operations.
- consumerUnSubscribeAllTopics(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
-
Unsubscribe from all the topics being consumed for the partition in partitionConsumptionState
- consumerUnSubscribeAllTopics(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- ConsumptionStateSnapshot - Class in com.linkedin.venice.admin.protocol.response
-
Type describes all the version attributes
- ConsumptionStateSnapshot() - Constructor for class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Default constructor.
- ConsumptionStateSnapshot(Integer, Boolean, Boolean, Object, Boolean, Boolean, Boolean, Boolean, CharSequence, Boolean, Long, Boolean, Long) - Constructor for class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
All-args constructor.
- contains(CharSequence) - Method in interface com.linkedin.alpini.base.misc.Headers
- contains(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- contains(CharSequence) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
- contains(CharSequence, CharSequence, boolean) - Method in interface com.linkedin.alpini.base.misc.Headers
- contains(CharSequence, CharSequence, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- contains(CharSequence, CharSequence, boolean) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
- contains(Object) - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
-
Returns true if this list contains the specified element.
- contains(Object) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
- contains(Object) - Method in class com.linkedin.venice.utils.collections.MemoryBoundBlockingQueue
- contains(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- contains(String, String, boolean) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- contains(T) - Method in class com.linkedin.venice.utils.ComplementSet
- containsAll(Collection<?>) - Method in class com.linkedin.venice.utils.collections.ArrayCollection
- containsAll(Collection<?>) - Method in class com.linkedin.venice.utils.collections.MemoryBoundBlockingQueue
- containsConfig(String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
- containsFabricToExecutionStatusMap(String) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
map<string, string> fabricToExecutionStatusMap = 5;
- containsFabricToExecutionStatusMap(String) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
map<string, string> fabricToExecutionStatusMap = 5;
- containsFabricToExecutionStatusMap(String) - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
map<string, string> fabricToExecutionStatusMap = 5;
- containsFactoryClass(String) - Method in class com.linkedin.venice.pubsub.PubSubPositionTypeRegistry
-
Checks if the given pubsub position factory class name is present in the registry.
- containsHeader(String) - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
- containsHelixResource(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- containsHelixResource(String, String) - Method in interface com.linkedin.venice.meta.StoreCleaner
-
This purpose of the function is to check if the given resource exists in the Helix cluster.
- containsHybridVersion(List<Version>) - Static method in interface com.linkedin.venice.meta.Version
- containsKafkaTopic(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- containsKafkaTopic(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
-
Whether this repository contains routing data for given kafka topic or not.
- containsKey(Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
-
Returns true if this map contains a mapping for the specified key.
- containsKey(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- containsOnlyOneCollection(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
-
Utility function that checks to make sure that given a union schema, there only exists 1 collection type amongst the provided types.
- containsPartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Return true or false based on whether a given partition exists within this storage engine
- containsPartition(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- containsPartition(int) - Method in interface com.linkedin.davinci.store.StorageEngine
-
Return true or false based on whether a given partition exists within this storage engine
- containsPersona(String) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
- containsResource(String) - Method in class com.linkedin.venice.helix.ResourceAssignment
-
Deprecated.
- containsResource(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Check if a resource exists in a cluster by checking its ideal state.
- containsResource(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- containsRunningConsumption(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- containsRunningConsumption(VeniceStoreVersionConfig) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
-
Check whether there is a running consumption task for given store.
- containsRunningConsumption(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- containsRunningConsumption(String) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
-
Check whether there is a running consumption task for given store version topic.
- containsTopic(PubSubTopic) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
-
Checks if a Kafka topic exists.
- containsTopic(PubSubTopic) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Checks if a PubSub topic exists.
- containsTopic(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- containsTopic(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- containsTopicAndAllPartitionsAreOnline(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- containsTopicAndAllPartitionsAreOnline(PubSubTopic, Integer) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
This is an extensive check to mitigate an edge-case where a topic is not yet created in all the brokers.
- containsTopicCached(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Retry up to a maximum number of attempts to get the expected result.
- containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
See Java doc of
PubSubAdminAdapter.containsTopicWithExpectationAndRetry(com.linkedin.venice.pubsub.api.PubSubTopic, int, boolean)
which provides exactly the same semantics. - containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean, Duration, Duration, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
- containsTopicWithExpectationAndRetry(PubSubTopic, int, boolean, Duration, Duration, Duration) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- containsTopicWithPartitionCheck(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
-
Checks if a topic exists and has the given partition
- containsTopicWithPartitionCheck(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Checks if a PubSub topic exists and has the given partition
- containsTopicWithPartitionCheck(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- containsTopicWithPartitionCheckExpectationAndRetry(PubSubTopicPartition, int, boolean) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
- containsTopicWithPartitionCheckExpectationAndRetry(PubSubTopicPartition, int, boolean, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
- containsTopicWithRetries(PubSubTopic, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- containsUpgradeHandler() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- containsValue(Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
-
Returns true if this map maps one or more keys to the specified value.
- containsVersion(int) - Method in class com.linkedin.venice.meta.AbstractStore
- containsVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- containsVersion(int) - Method in interface com.linkedin.venice.meta.Store
- content() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
- content() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
- content() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
- CONTENT_LENGTH - Static variable in enum class com.linkedin.alpini.base.misc.HeaderNames
- CONTENT_LOCATION - Static variable in enum class com.linkedin.alpini.base.misc.HeaderNames
- CONTENT_TYPE - Static variable in enum class com.linkedin.alpini.base.misc.HeaderNames
- ContentDecompressResult - Class in com.linkedin.venice.router.api
-
A POJO to store the response content and additional compression related metadata.
- ContentDecompressResult(ByteBuf, CompressionStrategy, long) - Constructor for class com.linkedin.venice.router.api.ContentDecompressResult
- context(boolean) - Method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
-
The default implementation for the anonymous classes below.
- context(boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
- CONTINUE - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- CONTROL_MESSAGE - Enum constant in enum class com.linkedin.venice.kafka.protocol.enums.MessageType
- CONTROL_MESSAGE_KAFKA_KEY_LENGTH - Static variable in class com.linkedin.venice.message.KafkaKey
-
For control messages, the Key part of the
KafkaKey
includes the producer GUID, segment and sequence number. - CONTROL_MESSAGE_KEY_HEADER_BYTE - Static variable in class com.linkedin.venice.kafka.protocol.enums.MessageType.Constants
- CONTROLLER - Enum constant in enum class com.linkedin.venice.acl.VeniceComponent
- CONTROLLER_ADD_VERSION_VIA_ADMIN_PROTOCOL - Static variable in class com.linkedin.venice.ConfigKeys
-
Flag to indicate whether to perform add version and start of ingestion via the admin protocol.
- CONTROLLER_ADMIN_GRPC_PORT - Static variable in class com.linkedin.venice.ConfigKeys
-
A port for the controller to listen on for incoming requests.
- CONTROLLER_ADMIN_SECURE_GRPC_PORT - Static variable in class com.linkedin.venice.ConfigKeys
-
A port for the controller to listen on for incoming requests.
- CONTROLLER_AUTO_MATERIALIZE_DAVINCI_PUSH_STATUS_SYSTEM_STORE - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_AUTO_MATERIALIZE_META_SYSTEM_STORE - Static variable in class com.linkedin.venice.ConfigKeys
-
This config controls whether to make an empty push to materialize meta system store for newly created user stores if possible.
- CONTROLLER_BACKUP_VERSION_DEFAULT_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
The following config is to control the default retention time in milliseconds if it is not specified in store level.
- CONTROLLER_BACKUP_VERSION_DELETION_SLEEP_MS - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_BACKUP_VERSION_METADATA_FETCH_BASED_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
The following config is to control whether to enable backup version cleanup based on router and server current version being served.
- CONTROLLER_BACKUP_VERSION_RETENTION_BASED_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
The following config is to control whether to enable backup version cleanup based on retention policy or not at cluster level.
- CONTROLLER_CLUSTER - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_CLUSTER_HELIX_CLOUD_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether the controller cluster is in a cloud environment.
- CONTROLLER_CLUSTER_LEADER_HAAS - Static variable in class com.linkedin.venice.ConfigKeys
-
Flag to indicate if the controller cluster leader will be amongst one of the local Helix as a library controllers or a Helix as a service controller running remotely.
- CONTROLLER_CLUSTER_REPLICA - Static variable in class com.linkedin.venice.ConfigKeys
-
Venice uses a helix cluster to assign controllers to each named venice cluster.
- CONTROLLER_CLUSTER_ZK_ADDRESSS - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_DANGLING_TOPIC_CLEAN_UP_INTERVAL_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
-
Time interval for checking dangling topics between 2 different types of pub sub backends.
- CONTROLLER_DANGLING_TOPIC_OCCURRENCE_THRESHOLD_FOR_CLEANUP - Static variable in class com.linkedin.venice.ConfigKeys
-
To avoid potential risk of race condition, if a topic is identified as dangling topic in number of times beyond this defined threshold, then this topic could be deleted.
- CONTROLLER_DEAD_STORE_ENDPOINT_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
If enabled, the controller's get dead store endpoint will be enabled.
- CONTROLLER_DEAD_STORE_STATS_CLASS_NAME - Static variable in class com.linkedin.venice.ConfigKeys
-
(Only matters if CONTROLLER_DEAD_STORE_ENDPOINT_ENABLED true).
- CONTROLLER_DEAD_STORE_STATS_PRE_FETCH_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
(Only matters if CONTROLLER_DEAD_STORE_ENDPOINT_ENABLED true) Allow the controller to pre-fetch dead store stats before the endpoint is called
- CONTROLLER_DEAD_STORE_STATS_PRE_FETCH_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
(Only matters if CONTROLLER_DEAD_STORE_ENDPOINT_ENABLED and CONTROLLER_DEAD_STORE_STATS_PRE_FETCH_ENABLED are true) Amount of time in milliseconds to wait before refetching the dead store stats
- CONTROLLER_DEAD_STORE_STATS_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
-
(Only matters if CONTROLLER_DEAD_STORE_ENDPOINT_ENABLED true) Prefix of configs to configure the DeadStoreStats implementation
- CONTROLLER_DEFAULT_HELIX_RESOURCE_CAPACITY_KEY - Static variable in class com.linkedin.venice.ConfigConstants
- CONTROLLER_DEFAULT_READ_QUOTA_PER_ROUTER - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_DEFERRED_VERSION_SWAP_SERVICE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Enables / disables the deferred version swap service.
- CONTROLLER_DEFERRED_VERSION_SWAP_SLEEP_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies how frequently the deferred version swap service runs.
- CONTROLLER_DISABLE_PARENT_REQUEST_TOPIC_FOR_STREAM_PUSHES - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_DISABLE_PARENT_TOPIC_TRUNCATION_UPON_COMPLETION - Static variable in class com.linkedin.venice.ConfigKeys
-
Test only config used to disable parent topic truncation upon job completion.
- CONTROLLER_DISABLED_REPLICA_ENABLER_INTERVAL_MS - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_DISABLED_ROUTES - Static variable in class com.linkedin.venice.ConfigKeys
-
List of forbidden admin paths
- CONTROLLER_EARLY_DELETE_BACKUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_ENABLE_DISABLED_REPLICA_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
The following config is to control whether to turn on disabled replica enabler service.
- CONTROLLER_ENABLE_HYBRID_STORE_PARTITION_COUNT_UPDATE - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_ENABLE_REAL_TIME_TOPIC_VERSIONING - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_ENFORCE_SSL - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether controller should enforce SSL.
- CONTROLLER_GRPC_SERVER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether to enable gRPC server in controller or not.
- CONTROLLER_GRPC_SERVER_THREAD_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
-
Number of threads to use for the gRPC server in controller.
- CONTROLLER_HAAS_SUPER_CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
-
The super cluster name for HAAS.
- CONTROLLER_HEARTBEAT_INSTANCE_NAME - Static variable in class com.linkedin.venice.common.PushStatusStoreUtils
- CONTROLLER_HELIX_CLOUD_ID - Static variable in class com.linkedin.venice.ConfigKeys
-
Specific id in cloud environment that belongs to this cluster.
- CONTROLLER_HELIX_CLOUD_INFO_PROCESSOR_NAME - Static variable in class com.linkedin.venice.ConfigKeys
-
Name of the class that processes the fetching and parsing of cloud information.
- CONTROLLER_HELIX_CLOUD_INFO_PROCESSOR_PACKAGE - Static variable in class com.linkedin.venice.ConfigKeys
-
Package name of the class that processes the fetching and parsing of cloud information.
- CONTROLLER_HELIX_CLOUD_INFO_SOURCES - Static variable in class com.linkedin.venice.ConfigKeys
-
Sources for retrieving the cloud information.
- CONTROLLER_HELIX_CLOUD_PROVIDER - Static variable in class com.linkedin.venice.ConfigKeys
-
What cloud environment the controller is in.
- CONTROLLER_HELIX_INSTANCE_CAPACITY - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies the capacity a controller instance can handle.
- CONTROLLER_HELIX_REBALANCE_PREFERENCE_EVENNESS - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies the value to use for Helix's rebalance preference for evenness when using Waged.
- CONTROLLER_HELIX_REBALANCE_PREFERENCE_FORCE_BASELINE_CONVERGE - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies the value to use for Helix's rebalance preference for force baseline convergence when using Waged.
- CONTROLLER_HELIX_REBALANCE_PREFERENCE_LESS_MOVEMENT - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies the value to use for Helix's rebalance preference for less movement when using Waged.
- CONTROLLER_HELIX_RESOURCE_CAPACITY_WEIGHT - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies the weight of each Helix resource.
- CONTROLLER_HELIX_REST_CUSTOMIZED_HEALTH_URL - Static variable in class com.linkedin.venice.ConfigKeys
-
Base URL for customized health checks triggered by Helix.
- CONTROLLER_INSTANCE_TAG_LIST - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_JETTY_CONFIG_OVERRIDE_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
-
Prefix of configs to configure Jetty server in Controller.
- CONTROLLER_MIN_SCHEMA_COUNT_TO_KEEP - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_PARENT_EXTERNAL_SUPERSET_SCHEMA_GENERATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether the superset schema generation in Parent Controller should be done via passed callback or not.
- CONTROLLER_PARENT_MODE - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether current controller is parent or not
- CONTROLLER_PARENT_REGION_STATE - Static variable in class com.linkedin.venice.ConfigKeys
-
This config specifies the state of the region of the parent controller.
- CONTROLLER_PARENT_SYSTEM_STORE_HEARTBEAT_CHECK_WAIT_TIME_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
-
The wait time before validating system store heartbeat during system store health check in parent controller.
- CONTROLLER_PARENT_SYSTEM_STORE_REPAIR_CHECK_INTERVAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
-
Frequency to run system store health check in parent controller.
- CONTROLLER_PARENT_SYSTEM_STORE_REPAIR_RETRY_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
-
The maximum retry count for parent controller to fix a bad system store.
- CONTROLLER_PARENT_SYSTEM_STORE_REPAIR_SERVICE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether to check system store health in parent controller.
- CONTROLLER_PROTOCOL_VERSION_AUTO_DETECTION_SERVICE_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Enables / disables protocol version auto-detection service in parent controller.
- CONTROLLER_PROTOCOL_VERSION_AUTO_DETECTION_SLEEP_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies the sleep time for the protocol version auto-detection service between each detection attempt.
- CONTROLLER_REPUSH_PREFIX - Static variable in class com.linkedin.venice.ConfigKeys
-
Prefix of configs to configure RepushOrchestrator
- CONTROLLER_REQUEST_RETRY_ATTEMPTS - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- CONTROLLER_RESOURCE_INSTANCE_GROUP_TAG - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_SCHEMA_VALIDATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Sets the default for whether to do schema validation or not for all stores
- CONTROLLER_SSL_CERTIFICATE_ATTRIBUTE_NAME - Static variable in class com.linkedin.venice.VeniceConstants
-
In a
HttpServletRequest
, we can get the client certificate by retrieving the following attribute. - CONTROLLER_SSL_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
This config defines whether SSL is enabled in controller.
- CONTROLLER_STORAGE_CLUSTER_HELIX_CLOUD_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether the controller storage cluster is in a cloud environment.
- CONTROLLER_STORE_GRAVEYARD_CLEANUP_DELAY_MINUTES - Static variable in class com.linkedin.venice.ConfigKeys
-
When store graveyard cleanup is enabled, delete the graveyard znode if it has not been changed for a specific time.
- CONTROLLER_STORE_GRAVEYARD_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether to enable graveyard cleanup for batch-only store at cluster level.
- CONTROLLER_STORE_GRAVEYARD_CLEANUP_SLEEP_INTERVAL_BETWEEN_LIST_FETCH_MINUTES - Static variable in class com.linkedin.venice.ConfigKeys
-
Sleep interval between each graveyard list fetch from ZK in StoreGraveyardCleanup service.
- CONTROLLER_SYSTEM_SCHEMA_CLUSTER_NAME - Static variable in class com.linkedin.venice.ConfigKeys
-
The name of the cluster that should host the special stores used to serve system schemas.
- CONTROLLER_SYSTEM_STORE_ACL_SYNCHRONIZATION_DELAY_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
The delay in ms between each synchronization attempt between the Venice store acls and its corresponding system store acls if any synchronization is needed.
- CONTROLLER_UNUSED_SCHEMA_CLEANUP_INTERVAL_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_UNUSED_VALUE_SCHEMA_CLEANUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Enable automatic removal of old unused schemas.
- CONTROLLER_ZK_SHARED_DAVINCI_PUSH_STATUS_SYSTEM_SCHEMA_STORE_AUTO_CREATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
- CONTROLLER_ZK_SHARED_META_SYSTEM_SCHEMA_STORE_AUTO_CREATION_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether to automatically create zk shared metadata system store in Controller or not
- ControllerApiConstants - Class in com.linkedin.venice.controllerapi
- ControllerApiConstants() - Constructor for class com.linkedin.venice.controllerapi.ControllerApiConstants
- ControllerClient - Class in com.linkedin.venice.controllerapi
- ControllerClient(String, String) - Constructor for class com.linkedin.venice.controllerapi.ControllerClient
- ControllerClient(String, String, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.ControllerClient
- ControllerClientBackedSystemSchemaInitializer - Class in com.linkedin.venice.system.store
- ControllerClientBackedSystemSchemaInitializer(AvroProtocolDefinition, String, Schema, UpdateStoreQueryParams, boolean, Optional<SSLFactory>, String, String, String, boolean) - Constructor for class com.linkedin.venice.system.store.ControllerClientBackedSystemSchemaInitializer
- ControllerClientFactory - Class in com.linkedin.venice.controllerapi
- ControllerClientFactory() - Constructor for class com.linkedin.venice.controllerapi.ControllerClientFactory
- controllerD2ServiceName - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- ControllerGrpcAuditLoggingInterceptor - Class in com.linkedin.venice.controller.grpc.server.interceptor
-
A gRPC server interceptor for audit logging.
- ControllerGrpcAuditLoggingInterceptor() - Constructor for class com.linkedin.venice.controller.grpc.server.interceptor.ControllerGrpcAuditLoggingInterceptor
- ControllerGrpcConstants - Class in com.linkedin.venice.controller.grpc
- ControllerGrpcErrorType - Enum Class in com.linkedin.venice.protocols.controller
-
Protobuf enum
com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
- ControllerGrpcRequestContext - Class in com.linkedin.venice.protocols.controller
- ControllerGrpcServerUtils - Class in com.linkedin.venice.controller.grpc.server
- ControllerGrpcServerUtils() - Constructor for class com.linkedin.venice.controller.grpc.server.ControllerGrpcServerUtils
- ControllerGrpcServerUtils.GrpcRequestHandler<T> - Interface in com.linkedin.venice.controller.grpc.server
- ControllerGrpcSslSessionInterceptor - Class in com.linkedin.venice.controller.grpc.server.interceptor
-
Intercepts gRPC calls to enforce SSL/TLS requirements and propagate client certificate and remote address details into the gRPC
Context
. - ControllerGrpcSslSessionInterceptor() - Constructor for class com.linkedin.venice.controller.grpc.server.interceptor.ControllerGrpcSslSessionInterceptor
- ControllerInstanceTagRefresher - Class in com.linkedin.venice.controller
-
PreConnectCallback is called after the participant registers its info in the cluster but before marking itself as LIVEINSTANCE.
- ControllerInstanceTagRefresher(SafeHelixManager, List<String>) - Constructor for class com.linkedin.venice.controller.ControllerInstanceTagRefresher
- ControllerRequestHandlerDependencies - Class in com.linkedin.venice.controller
-
Dependencies for VeniceControllerRequestHandler
- ControllerRequestHandlerDependencies.Builder - Class in com.linkedin.venice.controller
- ControllerRequestParamValidator - Class in com.linkedin.venice.controller.server
- ControllerRequestParamValidator() - Constructor for class com.linkedin.venice.controller.server.ControllerRequestParamValidator
- controllerRequestWithRetry(Supplier<ControllerResponse>, int) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
- ControllerResponse - Class in com.linkedin.venice.controllerapi
-
Extend this class to create response objects for the controller Any fields that must be in all responses can go here.
- ControllerResponse() - Constructor for class com.linkedin.venice.controllerapi.ControllerResponse
- controllerRetries - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- ControllerRoute - Enum Class in com.linkedin.venice.controllerapi
- ControllerRoutes - Class in com.linkedin.venice.controller.server
- ControllerRoutes(boolean, Optional<DynamicAccessController>, PubSubTopicRepository, VeniceControllerRequestHandler) - Constructor for class com.linkedin.venice.controller.server.ControllerRoutes
- controllerStatusPollRetries - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- ControllerTransport - Class in com.linkedin.venice.controllerapi
- ControllerTransport(Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.ControllerTransport
- ControlMessage - Class in com.linkedin.venice.kafka.protocol
-
ControlMessage payloads contain metadata about the stream of data, for validation and debuggability purposes.
- ControlMessage() - Constructor for class com.linkedin.venice.kafka.protocol.ControlMessage
-
Default constructor.
- ControlMessage(Integer, Map<CharSequence, CharSequence>, Object) - Constructor for class com.linkedin.venice.kafka.protocol.ControlMessage
-
All-args constructor.
- ControlMessageDumper - Class in com.linkedin.venice
- ControlMessageDumper(PubSubConsumerAdapter, String, int, int, int) - Constructor for class com.linkedin.venice.ControlMessageDumper
- controlMessageType - Variable in class com.linkedin.venice.kafka.protocol.ControlMessage
-
Using int because Avro Enums are not evolvable.
- ControlMessageType - Enum Class in com.linkedin.venice.kafka.protocol.enums
-
A simple enum to map the values of
ControlMessage.controlMessageType
N.B.: We maintain this enum manually because Avro's auto-generated enums do not support evolution (i.e.: adding values) properly. - controlMessageUnion - Variable in class com.linkedin.venice.kafka.protocol.ControlMessage
-
This contains the ControlMessage data which is specific to each type of ControlMessage.
- convert(String) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
-
Deprecated.
- convert(Schema) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
-
Deprecated.
- convert(Row, Schema) - Static method in class com.linkedin.venice.spark.utils.RowToAvroConverter
- CONVERT_VSON_SCHEMA - Enum constant in enum class com.linkedin.venice.Command
- convertCharSequenceMapToStringMap(Map<CharSequence, CharSequence>) - Static method in class com.linkedin.venice.utils.CollectionUtils
- convertFromValueRecordSchema(Schema) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
-
This method is the only entry point! Convert schema of a store value to its write-compute schema.
- convertFromValueRecordSchemaStr(String) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
- convertHelixMessageToVeniceMessage(Message) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
-
Convert Helix message to Venice Message.
- convertHostnameToMetricName(String) - Static method in class com.linkedin.venice.stats.StatsUtils
- convertInstanceToZNRecord(Instance) - Static method in class com.linkedin.venice.helix.HelixInstanceConverter
- convertKey(String, Schema) - Static method in class com.linkedin.venice.client.store.QueryTool
- convertLiveInstances(Collection<LiveInstance>) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- convertNSToMS(long) - Static method in class com.linkedin.venice.utils.LatencyUtils
- convertPartialUpdateToFullPut(Pair<Integer, Integer>, Object) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
- convertPubSubMessageToPubSubChangeEventMessage(DefaultPubSubMessage, PubSubTopicPartition) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- convertSizeFromLiteral(String) - Static method in class com.linkedin.venice.utils.VeniceProperties
- convertStringMapToCharSequenceMap(Map<String, String>) - Static method in class com.linkedin.venice.utils.CollectionUtils
- convertToKafkaSpecificHeaders(PubSubMessageHeaders) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaUtils
- convertToPosition(byte[]) - Method in class com.linkedin.venice.pubsub.PubSubPositionDeserializer
- convertToPosition(PubSubPositionWireFormat) - Method in class com.linkedin.venice.pubsub.PubSubPositionDeserializer
-
Converts a wire format position to a PubSubPosition
- convertToPosition(ByteBuffer) - Method in class com.linkedin.venice.pubsub.PubSubPositionDeserializer
- convertToSecureUrl(URL) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
-
Deprecated.
- convertToSecureUrl(URL, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
-
Deprecated.
- convertVeniceChangeCoordinateToStringAndEncode(VeniceChangeCoordinate) - Static method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
- convertVeniceMessageToHelixMessage(StatusMessage) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
-
Convert Venice message to Helix message.
- convertZNRecordToInstance(ZNRecord) - Static method in class com.linkedin.venice.helix.HelixInstanceConverter
- copy() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- copy() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
- copy() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
- copy() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
- copy() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
- copy() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
- copy(HttpHeaders) - Static method in enum class com.linkedin.alpini.netty4.misc.HttpUtils
-
Returns a deap copy of the passed in
HttpHeaders
. - copyByteArray(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
- copyOverStoreMetadata(String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- copyOverStoreSchemasAndConfigs(Admin) - Method in class com.linkedin.venice.controller.server.NewClusterBuildOutRoutes
- copyOverStoreSchemasAndConfigs(String, String, String, String) - Method in interface com.linkedin.venice.controller.Admin
- copyOverStoreSchemasAndConfigs(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- copyOverStoreSchemasAndConfigs(String, String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- copyStateToRetryRequestContext(MultiKeyRequestContext<K, V>) - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
- copyValueOf(ControllerResponse) - Method in class com.linkedin.venice.controllerapi.ControllerResponse
- copyValueOf(RepushJobResponse) - Method in class com.linkedin.venice.controllerapi.RepushJobResponse
-
This method copies the values of another RepushJobInstance.
- CorruptDataException - Exception in com.linkedin.venice.exceptions.validation
-
This exception is thrown when we detect corrupt data in the Kafka stream.
- CorruptDataException(Lazy<String>) - Constructor for exception com.linkedin.venice.exceptions.validation.CorruptDataException
- COSINE_SIMILARITY - Enum constant in enum class com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
- COSINE_SIMILARITY_RESULT_SCHEMA - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- COSINE_SIMILARITY_SPEC - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- cosineSimilarity(String, List<Float>, String) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- cosineSimilarity(String, List<Float>, String) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
-
Setup cosine-similarity operation.
- CosineSimilarity - Class in com.linkedin.venice.compute.protocol.request
- CosineSimilarity() - Constructor for class com.linkedin.venice.compute.protocol.request.CosineSimilarity
-
Default constructor.
- CosineSimilarity(CharSequence, List<Float>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.CosineSimilarity
-
All-args constructor.
- CosineSimilarityOperator - Class in com.linkedin.venice.compute
- CosineSimilarityOperator() - Constructor for class com.linkedin.venice.compute.CosineSimilarityOperator
- cosSimilarityParam - Variable in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
-
The passed feature vector, which will be used to execute cosine-similarity calculation against the field in the original value record
- count(String, String) - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
- count(String, String) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
-
Set up compute operation.
- count(Iterator<?>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
- Count - Class in com.linkedin.venice.compute.protocol.request
- Count() - Constructor for class com.linkedin.venice.compute.protocol.request.Count
-
Default constructor.
- Count(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.Count
-
All-args constructor.
- COUNT - Enum constant in enum class com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
- countAceEntries() - Method in class com.linkedin.venice.authorization.AclBinding
-
count the number of AceEntries in the AclBinding
- COUNTER - Enum constant in enum class com.linkedin.venice.stats.metrics.MetricType
-
For Counter: A simple counter that can be added to.
- CounterBackedMapReduceDataWriterTaskTracker - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.task
-
An interface to retrieve metrics related to data writer tasks after a MapReduce job has completed.
- CounterBackedMapReduceDataWriterTaskTracker(Counters) - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- countGroupByBucket(Map<String, Predicate<T>>, String...) - Method in interface com.linkedin.venice.client.store.ComputeAggregationRequestBuilder
-
Aggregation query where the content of specified fields are going to be grouped by buckets, with each bucket being defined by some
Predicate
, and each matching occurrence incrementing a count for its associated bucket, after which the bucket names to counts are going to be returned. - countGroupByValue(int, String...) - Method in interface com.linkedin.venice.client.store.ComputeAggregationRequestBuilder
-
Aggregation query where the content of specified fields are going to be grouped by their value, then the occurrence of each distinct value counted, after which the top K highest counts along with their associated values are going to be returned.
- CountOperator - Class in com.linkedin.venice.compute
- CountOperator() - Constructor for class com.linkedin.venice.compute.CountOperator
- countStringToNameRecordSchemas() - Static method in class com.linkedin.venice.utils.TestWriteUtils
- CRC32 - Enum constant in enum class com.linkedin.venice.kafka.validation.checksum.CheckSumType
-
Deprecated.
- CRC32CheckSum - Class in com.linkedin.venice.kafka.validation.checksum
-
Running checksum implementations based on CRC32.
- CRC32CheckSum() - Constructor for class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
- create() - Static method in class com.linkedin.venice.httpclient5.VeniceClientTlsStrategyBuilder
- create(int, byte[]) - Static method in class com.linkedin.davinci.store.record.ValueRecord
- create(int, ByteBuf) - Static method in class com.linkedin.davinci.store.record.ValueRecord
- create(PubSubAdminAdapterContext) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapterFactory
- create(PubSubAdminAdapterContext) - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterFactory
-
Creates a PubSub admin adapter.
- create(PubSubConsumerAdapterContext) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapterFactory
- create(PubSubConsumerAdapterContext) - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterFactory
-
Creates a PubSub consumer adapter.
- create(PubSubProducerAdapterContext) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapterFactory
- create(PubSubProducerAdapterContext) - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterFactory
-
Creates a producer adapter using the provided context.
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, MetricEntityState.TehutiSensorRegistrationFunction, TehutiMetricNameEnum, List<MeasurableStat>, Map<VeniceMetricsDimensions, String>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateGeneric
-
Overloaded Factory method for constructor with Tehuti parameters
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, MetricEntityState.TehutiSensorRegistrationFunction, TehutiMetricNameEnum, List<MeasurableStat>, Map<VeniceMetricsDimensions, String>, Attributes) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateBase
-
Overloaded Factory method for constructor with Tehuti parameters
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, MetricEntityState.TehutiSensorRegistrationFunction, TehutiMetricNameEnum, List<MeasurableStat>, Map<VeniceMetricsDimensions, String>, Class<E>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateOneEnum
-
Overloaded Factory method for constructor with Tehuti parameters
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, MetricEntityState.TehutiSensorRegistrationFunction, TehutiMetricNameEnum, List<MeasurableStat>, Map<VeniceMetricsDimensions, String>, Class<E1>, Class<E2>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateTwoEnums
-
Overloaded Factory method for constructor with Tehuti parameters
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, MetricEntityState.TehutiSensorRegistrationFunction, TehutiMetricNameEnum, List<MeasurableStat>, Map<VeniceMetricsDimensions, String>, Class<E1>, Class<E2>, Class<E3>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateThreeEnums
-
Overloaded Factory method for constructor with Tehuti parameters
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, Map<VeniceMetricsDimensions, String>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateGeneric
-
Factory method to keep the API consistent with other subclasses like
MetricEntityStateOneEnum
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, Map<VeniceMetricsDimensions, String>, Attributes) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateBase
-
Factory method to keep the API consistent with other subclasses like
MetricEntityStateOneEnum
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, Map<VeniceMetricsDimensions, String>, Class<E>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateOneEnum
-
Factory method with named parameters to ensure the passed in enumTypeClass are in the same order as E
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, Map<VeniceMetricsDimensions, String>, Class<E1>, Class<E2>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateTwoEnums
-
Factory method with named parameters to ensure the passed in enumTypeClass are in the same order as E
- create(MetricEntity, VeniceOpenTelemetryMetricsRepository, Map<VeniceMetricsDimensions, String>, Class<E1>, Class<E2>, Class<E3>) - Static method in class com.linkedin.venice.stats.metrics.MetricEntityStateThreeEnums
-
Factory method with named parameters to ensure the passed in enumTypeClass are in the same order as E
- create(F, S) - Static method in class com.linkedin.venice.utils.Pair
-
Deprecated.Static factory method that, unlike the constructor, performs generic inference saving some typing.
- create(ZkBaseDataAccessor<T>, String, T) - Static method in class com.linkedin.venice.utils.HelixUtils
- create(ZkBaseDataAccessor<T>, String, T, int) - Static method in class com.linkedin.venice.utils.HelixUtils
- create(Routes, StaticFilesConfiguration, ExceptionMapper, boolean) - Method in class com.linkedin.venice.controller.spark.VeniceSparkServerFactory
- CREATE_STORAGE_PERSONA - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- CREATE_STORAGE_PERSONA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- CREATE_TOPIC_RETRIABLE_EXCEPTIONS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
- createAclHandler(VeniceConfigLoader) - Static method in class com.linkedin.davinci.blobtransfer.BlobTransferUtils
-
Create the acl handler for blob transfer, for both DVC peers and server peers
- createAdminFactory(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- createAndVerifyStoreInAllRegions(String, ControllerClient, List<ControllerClient>) - Static method in class com.linkedin.venice.utils.TestUtils
- createAttributes(MetricEntity, Map<VeniceMetricsDimensions, String>, VeniceDimensionInterface...) - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- createAttributes(MetricEntity, Map<VeniceMetricsDimensions, String>, Map<VeniceMetricsDimensions, String>) - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- createBasicVeniceWriter() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- createBasicVeniceWriter() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
- createBinaryDecoder(byte[], int, int, BinaryDecoder) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
- createBinaryDecoder(byte[], int, int, BinaryDecoder) - Method in class com.linkedin.venice.serialization.avro.OptimizedKafkaValueSerializer
- createBlobTransferClientSslHandler(Optional<SSLFactory>) - Static method in class com.linkedin.davinci.blobtransfer.BlobTransferUtils
- createCheckpoint(RocksDB) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
- createChildren(List<PropertyKey>, List<T>) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- createChunkBytes(int, int) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createChunkedKeySuffix(int, int, int) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createChunkedRecord(byte[], int, int, int, int, PubSubTopicPartition) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createChunkValueManifestRecord(byte[], DefaultPubSubMessage, int, PubSubTopicPartition) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createClusterReadLock() - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
- createClusterWriteLock() - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
- createCollectionTimeStampSchema(String, String, Schema) - Static method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
-
Create a RECORD that keeps track of collection field's update metadata.
- createComplexVeniceWriter(VeniceWriterOptions) - Method in class com.linkedin.venice.writer.VeniceWriterFactory
- createCompressorWithDictionary(byte[], int) - Method in class com.linkedin.venice.compression.CompressorFactory
- createConfig(String, String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
- createConnectionManager(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
- createConsumerFactory(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- createControllerLeader(LiveInstance) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- createControllerMessage(Message) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- createCounter(MetricEntity) - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- CREATED - Enum constant in enum class com.linkedin.venice.meta.VersionStatus
-
Version is created and persisted inside ZK.
- CREATED - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- createD2GetRequest(String) - Static method in class com.linkedin.venice.D2.D2ClientUtils
- createD2GetRequest(String, Map<String, String>) - Static method in class com.linkedin.venice.D2.D2ClientUtils
- createD2PostRequest(String, Map<String, String>, byte[]) - Static method in class com.linkedin.venice.D2.D2ClientUtils
- createDecoder(int, int, int, boolean, int) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
- createDefaultDeserializer() - Static method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
- createDefaultPersona() - Static method in class com.linkedin.venice.utils.TestStoragePersonaUtils
- createDeleteRecord(byte[], byte[], PubSubTopicPartition) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createDirectoryWithPermission(Path, FsPermission) - Static method in class com.linkedin.venice.hadoop.utils.HadoopUtils
-
Create a temporary directory with the given name under the given path and set the specified permissions.
- createdTime - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- createdTime - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Timestamp when this store was created.
- createdTime - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Time when this version was created.
- createEncoder() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
- createExecution(String) - Method in class com.linkedin.venice.controller.AdminCommandExecutionTracker
-
Create an execution context of a command.
- createExecutorService(int) - Method in class com.linkedin.venice.controller.multitaskscheduler.ScheduledTaskManager
- createExecutorService(int) - Method in class com.linkedin.venice.controller.multitaskscheduler.StoreMigrationManager
- createFlattenedUnionSchema(List<Schema>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
- createFromByteBuffer(ByteBuffer) - Method in class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPositionFactory
- createFromByteBuffer(ByteBuffer) - Method in class com.linkedin.venice.pubsub.EarliestPositionFactory
- createFromByteBuffer(ByteBuffer) - Method in class com.linkedin.venice.pubsub.LatestPositionFactory
- createFromByteBuffer(ByteBuffer) - Method in class com.linkedin.venice.pubsub.PubSubPositionFactory
-
Deserializes a
PubSubPosition
from the given byte buffer. - createFromWireFormat(PubSubPositionWireFormat) - Method in class com.linkedin.venice.pubsub.PubSubPositionFactory
-
Creates a
PubSubPosition
instance by deserializing the providedPubSubPositionWireFormat
. - createGenericRecord(Schema) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
-
Create a
GenericRecord
from a given schema. - createHeartbeatSender(String, VeniceProperties, ControllerClient, Optional<Properties>) - Method in class com.linkedin.venice.heartbeat.DefaultPushJobHeartbeatSenderFactory
- createHeartbeatSender(String, VeniceProperties, ControllerClient, Optional<Properties>) - Method in class com.linkedin.venice.heartbeat.NoOpPushJobHeartbeatSenderFactory
- createHeartbeatSender(String, VeniceProperties, ControllerClient, Optional<Properties>) - Method in interface com.linkedin.venice.heartbeat.PushJobHeartbeatSenderFactory
-
Create a heartbeat sender
- createHelixResourceAndStartMonitoring(String, String, Version) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Create Helix-resources for a given storage node cluster and starts monitoring a new push.
- createHistogram(MetricEntity) - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- createHttp2MultiplexHandler(ChannelHandler) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
- createHttp2PipelineInitializer() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- createHttp2PipelineInitializer(Consumer<ChannelPipeline>) - Method in class com.linkedin.venice.listener.VeniceHttp2PipelineInitializerBuilder
-
This function will leverage the existing HTTP/1.1 pipeline for both HTTP/1.1 and HTTP/2.
- createHttp2StreamFrameToHttpObjectCodec(boolean) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
- createIngestionTaskReport() - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- createIngestionTaskReport(IngestionReportType, String, int, long, String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- createIngestionTaskReport(IngestionReportType, String, int, String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- createIngestionTaskReport(String, int) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- createInstance(String) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- createInstrument(MetricEntity) - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- createInternalMetricEntityWithoutDimensions(String, MetricType, MetricUnit, String, String) - Static method in class com.linkedin.venice.stats.metrics.MetricEntity
- createInvalidMessage() - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
- createInvalidMessage() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
- createInvalidMessage(long, long) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
- createKafkaConsumerProperties(Properties, String, boolean) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Override the
ConfigKeys.KAFKA_BOOTSTRAP_SERVERS
config with a remote Kafka bootstrap url. - createKafkaConsumerService(Properties) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
-
Create a new
KafkaConsumerService
given consumerProperties which must contain a value for "bootstrap.servers". - createKafkaMessageEnvelope(MessageType, int, int) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createKey() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
- createKeySchema(String, SchemaEntry) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- createKeySerializer() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
-
Clients using different protocols for deserialized data (e.g VSON, Proto, etc) can override this method to serialize the respective POJO to Avro bytes
- createKeySerializer() - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
-
Deprecated.
- createKillAction(PubSubTopic, int) - Static method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
-
Create a kill consumer action.
- createListenerService(StorageEngineRepository, ReadOnlyStoreRepository, ReadOnlySchemaRepository, CompletableFuture<HelixCustomizedViewOfflinePushRepository>, IngestionMetadataRetriever, ReadMetadataRetriever, VeniceServerConfig, MetricsRepository, Optional<SSLFactory>, Optional<StaticAccessController>, Optional<DynamicAccessController>, DiskHealthCheckService, StorageEngineBackedCompressorFactory, Optional<ResourceReadUsageTracker>) - Method in class com.linkedin.venice.server.VeniceServer
- createMaintenance(MaintenanceSignal) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- createMergeConflictResolver(StringAnnotatedStoreSchemaCache, RmdSerDe, String) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolverFactory
- createMergeConflictResolver(StringAnnotatedStoreSchemaCache, RmdSerDe, String, boolean, boolean) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolverFactory
- createMessage(String[]) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
- createMessage(String[]) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequestDecoder
- createMessage(String[], boolean, long, long) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
- createMetric(TehutiMetricNameEnum, List<MeasurableStat>, MetricEntityState.TehutiSensorRegistrationFunction) - Method in class com.linkedin.venice.stats.metrics.MetricEntityState
- createMultiThreadedMetricsRepository() - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
- createNewStateModel(String, String) - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
-
This method will be invoked only once per partition per session
- createNewStateModel(String, String) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory
- createNewStateModel(String, String) - Method in class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
- createNewStateModel(String, String) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
- createNewStore(String, String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- createNewStore(String, String, String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- createNewStoreWithParameters(String, String, String, String, UpdateStoreQueryParams) - Method in class com.linkedin.venice.controllerapi.ControllerClient
-
Simplified API that wraps together the store create and update functionalities with some clean up functionality
- createNewSystemStore(String, String, String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- createOfflinePushStatusAndItsPartitionStatuses(OfflinePushStatus) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
- createOfflinePushStatusAndItsPartitionStatuses(OfflinePushStatus) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
-
Create offline push and its partition statues on persistent storage.
- createOptimizedBinaryDecoder(byte[], int, int) - Method in class org.apache.avro.io.OptimizedBinaryDecoderFactory
-
This function will create an optimized binary decoder.
- createOptimizedBinaryDecoder(ByteBuffer) - Method in class org.apache.avro.io.OptimizedBinaryDecoderFactory
- createOptimizedDeserializer() - Static method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
- createPause(PauseSignal) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- createPerFieldTimestampRecord(Schema, long, GenericRecord) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolver
- createPersona(StoragePersona) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
- createPersona(String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
-
Note that this method does not return an error if the persona already exists.
- createProducer(ClientConfig, VeniceProperties, ICProvider) - Static method in class com.linkedin.venice.producer.online.OnlineProducerFactory
- createProducerCallback(DefaultPubSubMessage, PartitionConsumptionState, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- createProducerCallback(DefaultPubSubMessage, PartitionConsumptionState, LeaderProducedRecordContext, int, String, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- createProducerFactory(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- createPutRecord(byte[], byte[], byte[], PubSubTopicPartition) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createReader(InputPartition) - Method in class com.linkedin.venice.spark.input.hdfs.VeniceHdfsInputPartitionReaderFactory
- createReaderFactory() - Method in class com.linkedin.venice.spark.input.hdfs.VeniceHdfsInputScan
- createRecordIterator(VeniceProperties, InputPartition) - Method in class com.linkedin.venice.spark.input.hdfs.VeniceHdfsInputPartitionReader
- createRecordIterator(VeniceProperties, InputPartition) - Method in class com.linkedin.venice.spark.input.VeniceAbstractPartitionReader
- createReplicationMetadataPayload(int) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createRepushInfo(Version, String, String, String) - Static method in class com.linkedin.venice.controllerapi.RepushInfo
- createRequestHandler(ThreadPoolExecutor, ThreadPoolExecutor, StorageEngineRepository, ReadOnlyStoreRepository, ReadOnlySchemaRepository, IngestionMetadataRetriever, ReadMetadataRetriever, DiskHealthCheckService, StorageEngineBackedCompressorFactory, Optional<ResourceReadUsageTracker>) - Method in class com.linkedin.venice.listener.ListenerService
- createRetryRequestContext() - Method in class com.linkedin.venice.fastclient.GetRequestContext
- createRetryRequestContext(int) - Method in class com.linkedin.venice.fastclient.BatchGetRequestContext
- createRetryRequestContext(int) - Method in class com.linkedin.venice.fastclient.ComputeRequestContext
- createRouterClusterConfig() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
- createRouterClusterConfig() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
- createRouterRequestKey(ByteBuffer, int, int) - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
- createRouterRequestKey(ByteBuffer, int, int) - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
- createRouterRequestKey(ByteBuffer, int, int) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
-
Create a router request key.
- createSecureSocketConnector(Server, String, int, SslStores, boolean) - Static method in class com.linkedin.venice.controller.spark.VeniceSocketConnectorFactory
-
Creates a ssl jetty socket jetty.
- createSingleThreadedMetricsRepository() - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
- createSingleThreadedMetricsRepository(long, long) - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
- createSingleThreadedVeniceMetricsRepository() - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
- createSingleThreadedVeniceMetricsRepository(boolean, VeniceOpenTelemetryMetricNamingFormat, Collection<MetricEntity>) - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
- createSingleThreadedVeniceMetricsRepository(long, long, boolean, VeniceOpenTelemetryMetricNamingFormat, Collection<MetricEntity>) - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
- createSnapshot() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Creates a snapshot of the current state of the storage if the blob transfer feature is enabled via the store configuration
- createSnapshot() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- createSnapshot() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- createSnapshot() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- createSnapshot() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- createSnapshot(String, int) - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Create a snapshot for a particular partition
- createSnapshot(RocksDB, String) - Static method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
-
util method to create a snapshot It will check the snapshot directory and delete it if it exists, then generate a new snapshot
- createSocketConnector(Server, String, int, boolean) - Static method in class com.linkedin.venice.controller.spark.VeniceSocketConnectorFactory
-
Creates an ordinary, non-secured Jetty server jetty.
- createSourceOfTruthAdminFactory(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- createSpecificVersionTopic(String, String, Version) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Create the corresponding version topic based on the provided
Version
- createSslEngine(ByteBufAllocator, SocketAddress) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
- createSSLEngine(ByteBufAllocator, boolean) - Method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
- createSSLEngine(ByteBufAllocator, boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
- createSSLEngine(ByteBufAllocator, String, int, boolean) - Method in interface com.linkedin.alpini.netty4.ssl.SSLEngineFactory
- createSSLEngine(ByteBufAllocator, String, int, boolean) - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
- createSSLFactory(boolean, String, Lazy<Properties>) - Static method in class com.linkedin.venice.hadoop.utils.VPJSSLUtils
- createSSLFactoryForBlobTransferInDVC(VeniceConfigLoader) - Static method in class com.linkedin.davinci.blobtransfer.BlobTransferUtils
-
Create an SSLFactory from the Venice config loader
- createStateModelDef(StateModelDefinition) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
- createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
- createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngine
- createStoragePartition(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
- createStoragePersona(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
- createStoragePersona(String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- createStoragePersona(String, String, long, Set<String>, Set<String>) - Method in interface com.linkedin.venice.controller.Admin
- createStoragePersona(String, String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- createStoragePersona(String, String, long, Set<String>, Set<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Creates a new persona with the given parameters.
- CreateStoragePersona - Class in com.linkedin.venice.controller.kafka.protocol.admin
- CreateStoragePersona() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
-
Default constructor.
- CreateStoragePersona(CharSequence, CharSequence, Long, List<CharSequence>, List<CharSequence>) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
-
All-args constructor.
- createStore(Admin, StoreRequestHandler) - Method in class com.linkedin.venice.controller.server.CreateStore
- createStore(CreateStoreGrpcRequest) - Method in class com.linkedin.venice.controller.server.StoreRequestHandler
-
Creates a new store in the specified Venice cluster with the provided parameters.
- createStore(CreateStoreGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceBlockingStub
- createStore(CreateStoreGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceFutureStub
- createStore(CreateStoreGrpcRequest, StreamObserver<CreateStoreGrpcResponse>) - Method in class com.linkedin.venice.controller.grpc.server.StoreGrpcServiceImpl
- createStore(CreateStoreGrpcRequest, StreamObserver<CreateStoreGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.AsyncService
- createStore(CreateStoreGrpcRequest, StreamObserver<CreateStoreGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceStub
- createStore(String, String, String, String, String) - Method in interface com.linkedin.venice.controller.Admin
- createStore(String, String, String, String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
- createStore(String, String, String, String, String, boolean, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
- createStore(String, String, String, String, String, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Create a new ZK store and its configuration in the store repository and create schemas in the schema repository.
- createStore(String, String, String, String, String, boolean, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Create a store by sending
STORE_CREATION
admin message to the Kafka admin topic, sendingMETA_SYSTEM_STORE_AUTO_CREATION_VALIDATION
admin message, and performing initialization steps for using authorize server to manage ACLs for the input store. - CreateStore - Class in com.linkedin.venice.controller.server
- CreateStore(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.CreateStore
- CreateStoreGrpcRequest - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- CreateStoreGrpcRequest.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- CreateStoreGrpcRequestOrBuilder - Interface in com.linkedin.venice.protocols.controller
- CreateStoreGrpcResponse - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- CreateStoreGrpcResponse.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- CreateStoreGrpcResponseOrBuilder - Interface in com.linkedin.venice.protocols.controller
- createStoreMigrationManager(int, int) - Static method in class com.linkedin.venice.controller.multitaskscheduler.StoreMigrationManager
- createStoreReadLock(String) - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
- createStoreRequestValidator(String, String, String, String, String) - Static method in class com.linkedin.venice.controller.server.ControllerRequestParamValidator
- createStoreSchemaFetcher(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
- createStoreWriteLock(String) - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
- createStoreWriteLockOnly(String) - Method in class com.linkedin.venice.utils.locks.ClusterLockManager
- createSystemProducer(String, String, String, Version.PushType, String, String, boolean, Config, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Deprecated.Left in to maintain backward compatibility
- createSystemProducer(String, String, String, Version.PushType, String, String, Config, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Deprecated.Left in to maintain backward compatibility
- createSystemProducer(String, String, String, String, Version.PushType, String, String, boolean, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Construct a new instance of
VeniceSystemProducer
- createSystemProducer(String, String, String, String, Version.PushType, String, String, boolean, Config, Optional<SSLFactory>, Optional<String>) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Construct a new instance of
VeniceSystemProducer
- createTableStatement(TableDefinition) - Static method in class com.linkedin.venice.sql.SQLUtils
- createTestETLStoreConfig() - Static method in class com.linkedin.venice.utils.TestUtils
- createTestHybridStoreConfig(Random) - Static method in class com.linkedin.venice.utils.TestUtils
- createTestPartitionerConfig(Random) - Static method in class com.linkedin.venice.utils.TestUtils
- createTestStore(String, String, long) - Static method in class com.linkedin.venice.utils.TestUtils
- createTestSystemStoreAttributes(String, Random) - Static method in class com.linkedin.venice.utils.TestUtils
- createTestSystemStores(String, Random) - Static method in class com.linkedin.venice.utils.TestUtils
- createTestVersions(String, Random) - Static method in class com.linkedin.venice.utils.TestUtils
- createTestViewConfigs(Random) - Static method in class com.linkedin.venice.utils.TestUtils
- createTestViewParams(Random) - Static method in class com.linkedin.venice.utils.TestUtils
- createThreadPool(int, String, int) - Method in class com.linkedin.venice.listener.ListenerService
- createThreadPool(int, String, int, BlockingQueueType) - Static method in class com.linkedin.venice.utils.concurrent.ThreadPoolFactory
- createThreadPool(int, String, Object, int, BlockingQueueType) - Static method in class com.linkedin.venice.utils.concurrent.ThreadPoolFactory
- createTopic(PubSubTopic, int, int, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Create a topic, and block until the topic is created, with a default timeout of 30000, after which this function will throw a VeniceException.
- createTopic(PubSubTopic, int, int, boolean, boolean, Optional<Integer>) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- createTopic(PubSubTopic, int, int, boolean, boolean, Optional<Integer>, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Create a topic, and block until the topic is created, with a default timeout of 30000, after which this function will throw a VeniceException.
- createTopic(PubSubTopic, int, int, long, boolean, Optional<Integer>, boolean) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Create a topic, and block until the topic is created, with a default timeout of 30000, after which this function will throw a VeniceException.
- createTopic(PubSubTopic, int, int, PubSubTopicConfiguration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
-
Creates a new topic in the PubSub system with the given parameters.
- createTopic(PubSubTopic, int, int, PubSubTopicConfiguration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Creates a new topic in the PubSub system with the given parameters.
- createTopic(PubSubTopic, int, int, PubSubTopicConfiguration) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- createTopic(String, int) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
- createUpdateRecord(byte[], byte[], PubSubTopicPartition) - Static method in class com.linkedin.venice.utils.ChunkingTestUtils
- createValue() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
- createVeniceControllerCluster() - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Create and configure the Venice controller cluster.
- createVeniceControllerCluster() - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- createVeniceStorageCluster(String, ClusterConfig, RESTConfig) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Create and configure the Venice storage cluster.
- createVeniceStorageCluster(String, ClusterConfig, RESTConfig) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- createVeniceStorageClusterResources(String, String, int, int) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Create resources for a given storage node cluster.
- createVeniceStorageClusterResources(String, String, int, int) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- createVeniceWriter(VeniceWriterOptions) - Method in class com.linkedin.venice.writer.VeniceWriterFactory
- CreateVersion - Class in com.linkedin.venice.controller.server
-
This class will add a new version to the given store.
- CreateVersion(boolean, Optional<DynamicAccessController>, boolean, boolean) - Constructor for class com.linkedin.venice.controller.server.CreateVersion
- createVersionSpecificCompressorIfNotExist(CompressionStrategy, String, byte[]) - Method in class com.linkedin.venice.compression.CompressorFactory
- createVersionSpecificCompressorIfNotExist(CompressionStrategy, String, byte[], int) - Method in class com.linkedin.venice.compression.CompressorFactory
- createVersionWithBatchData(ControllerClient, String, String, String, Stream<Map.Entry>, int, PubSubProducerAdapterFactory, Map<String, String>, PubSubPositionTypeRegistry) - Static method in class com.linkedin.venice.utils.TestUtils
- createVersionWithBatchData(ControllerClient, String, String, String, Stream<Map.Entry>, PubSubProducerAdapterFactory, Map<String, String>, PubSubPositionTypeRegistry) - Static method in class com.linkedin.venice.utils.TestUtils
- creationTime - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
- credentials - Variable in class com.linkedin.venice.grpc.VeniceGrpcServer
- CURRENT - Enum constant in enum class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext.VersionRole
- CURRENT_CONSUMING_VERSION - Enum constant in enum class com.linkedin.davinci.consumer.stats.BasicConsumerStats.BasicConsumerMetricEntity
-
Measures the min/max consuming version across all subscribed partitions
- CURRENT_VERSION - Enum constant in enum class com.linkedin.venice.controllerapi.routes.V1Get
- CURRENT_VERSION - Enum constant in enum class com.linkedin.venice.controllerapi.routes.V1Put
- CURRENT_VERSION - Enum constant in enum class com.linkedin.venice.meta.QueryAction
- CURRENT_VERSION_AA_WC_LEADER_POOL - Enum constant in enum class com.linkedin.davinci.kafka.consumer.ConsumerPoolType
-
The followings pool types are being used when current version prioritization strategy is enabled.
- CURRENT_VERSION_IS_NEWER - Enum constant in enum class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
- CURRENT_VERSION_NON_AA_WC_LEADER_POOL - Enum constant in enum class com.linkedin.davinci.kafka.consumer.ConsumerPoolType
- CURRENT_VERSION_PRIORITIZATION - Enum constant in enum class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategyType
- CURRENT_VERSION_SEP_RT_LEADER_POOL - Enum constant in enum class com.linkedin.davinci.kafka.consumer.ConsumerPoolType
- currentContext() - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
- currentProtocolVersion - Variable in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
-
The protocol version that is currently in use.
- currentRTVersionNumber - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
current RT version number that should be used to formulate real time topic name during add version
- currentStep(int) - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Builder
- CurrentStoreStates - Class in com.linkedin.venice.meta.systemstore.schemas
-
This type of store metadata describes the current states of the store in a given fabric and Venice cluster.
- CurrentStoreStates() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
-
Default constructor.
- CurrentStoreStates(StoreProperties) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
-
All-args constructor.
- currentTermStartPubSubPosition - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
The pubsub position marking the start of the current leader's term in the version topic.
- currentTimeMillis() - Static method in enum class com.linkedin.alpini.base.misc.Time
- currentValue - Variable in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
-
The current value of this record as of this change event.
- currentVersion - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
- currentVersion - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- currentVersion - Variable in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
-
The version number that is currently used to serve read traffic
- currentVersion - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- currentVersion - Variable in class com.linkedin.venice.metadata.response.VersionProperties
-
Current version number
- currentVersion - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
The number of version which is used currently.
- currentVersion - Variable in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
- CurrentVersionConsumerPoolStrategy() - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.CurrentVersionConsumerPoolStrategy
- currentVersionHighWatermarks - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- currentVersionLastHeartbeat - Variable in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- CurrentVersionRequest - Class in com.linkedin.venice.listener.request
- CurrentVersionResponse - Class in com.linkedin.venice.controllerapi
- CurrentVersionResponse() - Constructor for class com.linkedin.venice.controllerapi.CurrentVersionResponse
- currentVersionStates - Variable in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
-
An array of version states describing the current state of an given fabric.
- CurrentVersionStates - Class in com.linkedin.venice.meta.systemstore.schemas
-
This type of store metadata describes the current version states of the store in a given fabric and Venice cluster.
- CurrentVersionStates() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
-
Default constructor.
- CurrentVersionStates(List<StoreVersionState>, Integer) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
-
All-args constructor.
- CUSTOMIZEDVIEW - Enum constant in enum class com.linkedin.venice.helix.HelixViewPropertyType
- CV_PUSH_MONITOR_FOR_LF_STORE - Enum constant in enum class com.linkedin.venice.pushmonitor.PushMonitorType
D
- D2_SERVICE_DISCOVERY_RESPONSE_V2_ENABLED - Static variable in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponseV2
-
Deprecated.
- D2_ZK_HOSTS_ADDRESS - Static variable in class com.linkedin.venice.ConfigKeys
-
ZooKeeper address of d2 client.
- D2_ZK_HOSTS_PREFIX - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
This config specifies the prefix for d2 zk hosts config.
- d2Client - Variable in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- D2ClientFactory - Class in com.linkedin.venice.d2
- D2ClientFactory() - Constructor for class com.linkedin.venice.d2.D2ClientFactory
- D2ClientUtils - Class in com.linkedin.venice.D2
- D2ClientUtils() - Constructor for class com.linkedin.venice.D2.D2ClientUtils
- D2ControllerClient - Class in com.linkedin.venice.controllerapi
- D2ControllerClient(String, String, D2Client) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
- D2ControllerClient(String, String, D2Client, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
- D2ControllerClient(String, String, String, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
- D2ControllerClient(String, String, List<D2Client>, Optional<SSLFactory>) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
- D2ControllerClient(String, String, Optional<SSLFactory>, List<String>) - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClient
- D2ControllerClientFactory - Class in com.linkedin.venice.controllerapi
- D2ControllerClientFactory() - Constructor for class com.linkedin.venice.controllerapi.D2ControllerClientFactory
- D2HealthChecker - Class in com.linkedin.venice.d2
-
Runs a daemon thread that consistently sends HTTP GET request to admin healthcheck endpoint.
- D2HealthChecker(ZooKeeperConnectionManager, long, String, int, ScheduledExecutorService, int) - Constructor for class com.linkedin.venice.d2.D2HealthChecker
- d2Routing - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- D2Server - Class in com.linkedin.venice.d2
- D2Server(D2ServerManager) - Constructor for class com.linkedin.venice.d2.D2Server
- D2ServerManager - Class in com.linkedin.venice.d2
-
This class provides a server manager with start/shutdown methods to be invoked to manage the lifecycle of the server announcer.
- D2ServerManager(ZooKeeperConnectionManager, long, boolean, long, boolean, boolean) - Constructor for class com.linkedin.venice.d2.D2ServerManager
- D2ServerManager(ZooKeeperConnectionManager, long, boolean, long, boolean, boolean, boolean, boolean, boolean, long, int, String, ScheduledExecutorService, int) - Constructor for class com.linkedin.venice.d2.D2ServerManager
- D2SERVICE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- D2ServiceDiscovery - Class in com.linkedin.venice.client.store
-
This class is used to find the proper d2 service name for the given store through default D2 service d2://VeniceRouter.
- D2ServiceDiscovery() - Constructor for class com.linkedin.venice.client.store.D2ServiceDiscovery
- D2ServiceDiscovery(Time) - Constructor for class com.linkedin.venice.client.store.D2ServiceDiscovery
- D2ServiceDiscoveryResponse - Class in com.linkedin.venice.controllerapi
- D2ServiceDiscoveryResponse() - Constructor for class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
- D2ServiceDiscoveryResponseV2 - Class in com.linkedin.venice.controllerapi
-
Deprecated.
- D2ServiceDiscoveryResponseV2() - Constructor for class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponseV2
-
Deprecated.
- D2Stats - Class in com.linkedin.venice.stats
- D2Stats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.D2Stats
- D2TransportClient - Class in com.linkedin.venice.client.store.transport
-
D2Client
based TransportClient implementation. - D2TransportClient(String, D2Client) - Constructor for class com.linkedin.venice.client.store.transport.D2TransportClient
-
Construct by an existing D2Client (such as from the pegasus-d2-client-default-cmpt).
- D2TransportClient(String, ClientConfig) - Constructor for class com.linkedin.venice.client.store.transport.D2TransportClient
-
Construct by customized zookeeper and other configs.
- DA_VINCI_CURRENT_VERSION_BOOTSTRAPPING_QUOTA_BYTES_PER_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
-
When
ConfigKeys.DA_VINCI_CURRENT_VERSION_BOOTSTRAPPING_SPEEDUP_ENABLED
is true, the following throttler will be applied when any current version is bootstrapping. - DA_VINCI_CURRENT_VERSION_BOOTSTRAPPING_QUOTA_RECORDS_PER_SECOND - Static variable in class com.linkedin.venice.ConfigKeys
-
When
ConfigKeys.DA_VINCI_CURRENT_VERSION_BOOTSTRAPPING_SPEEDUP_ENABLED
is true, the following throttler will be applied when any current version is bootstrapping. - DA_VINCI_CURRENT_VERSION_BOOTSTRAPPING_SPEEDUP_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether to speed up DaVinci current version bootstrapping or not.
- DA_VINCI_SUBSCRIBE_ON_DISK_PARTITIONS_AUTOMATICALLY - Static variable in class com.linkedin.venice.ConfigKeys
- daemonThreadFactory() - Static method in enum class com.linkedin.alpini.base.concurrency.Executors
- DaemonThreadFactory - Class in com.linkedin.venice.utils
-
A thread factory that sets the threads to run as daemons.
- DaemonThreadFactory(String) - Constructor for class com.linkedin.venice.utils.DaemonThreadFactory
- DaemonThreadFactory(String, Object) - Constructor for class com.linkedin.venice.utils.DaemonThreadFactory
- DATA_BASE_PATH - Static variable in class com.linkedin.venice.ConfigKeys
- DATA_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
- DATA_RECOVERY - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- DATA_RECOVERY_COMPLETED - Enum constant in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
- DATA_RECOVERY_COMPLETED - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
- DATA_RECOVERY_COPY_ALL_VERSION_CONFIGS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
-
Whether or not to copy all version configs from the source fabric when performing data recovery in a destination fabric.
- DATA_REPLICATION_POLICY - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DATA_WRITER_COMPLETED - Enum constant in enum class com.linkedin.venice.status.PushJobDetailsStatus
- DATA_WRITER_COMPUTE_JOB_CLASS - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
Config to set the class for the DataWriter job.
- DATA_WRITER_JOB_COMPLETED - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- dataAccessor - Variable in class com.linkedin.venice.helix.HelixStoreGraveyard
- databaseInfo - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
A map of string -> string to store database related info, which is necessary to checkpoint
- databaseSyncBytesIntervalForDeferredWriteMode - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Message bytes consuming interval before persisting offset in offset db for deferred-write database.
- databaseSyncBytesIntervalForTransactionalMode - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Message bytes consuming interval before persisting offset in offset db for transactional mode database.
- DataIntegrityValidator - Class in com.linkedin.davinci.validation
-
Colloquially known as DIV (Data Integrity Validator).
- DataIntegrityValidator(String) - Constructor for class com.linkedin.davinci.validation.DataIntegrityValidator
- DataIntegrityValidator(String, long) - Constructor for class com.linkedin.davinci.validation.DataIntegrityValidator
-
This constructor is used by a proprietary ETL project.
- DataIntegrityValidator(String, long, long) - Constructor for class com.linkedin.davinci.validation.DataIntegrityValidator
- dataModel() - Method in interface com.linkedin.venice.meta.DataModelBackedStructure
-
Return the backed data model.
- dataModel() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
- dataModel() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
- dataModel() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- dataModel() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
- dataModel() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- dataModel() - Method in class com.linkedin.venice.meta.ReadOnlyViewConfig
- dataModel() - Method in class com.linkedin.venice.meta.StoreConfig
- dataModel() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
- dataModel() - Method in class com.linkedin.venice.meta.VersionImpl
- dataModel() - Method in class com.linkedin.venice.meta.ViewConfigImpl
- dataModel() - Method in class com.linkedin.venice.meta.ZKStore
- DataModelBackedStructure<T extends org.apache.avro.specific.SpecificRecord> - Interface in com.linkedin.venice.meta
- DataProviderUtils - Class in com.linkedin.venice.utils
-
This class gathers all common data provider patterns in test cases.
- DataProviderUtils() - Constructor for class com.linkedin.venice.utils.DataProviderUtils
- dataRecovery(Admin) - Method in class com.linkedin.venice.controller.server.DataRecoveryRoutes
- dataRecovery(String, String, String, int, boolean, boolean, Optional<Version>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- DataRecoveryClient - Class in com.linkedin.venice.datarecovery
-
DataRecoveryClient is the central class to manage data recovery feature.
- DataRecoveryClient() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryClient
- DataRecoveryClient(DataRecoveryExecutor, DataRecoveryMonitor, DataRecoveryEstimator) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryClient
- DataRecoveryClient.DataRecoveryParams - Class in com.linkedin.venice.datarecovery
- dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
- dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
- dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
- dataRecoveryCompleted(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
- dataRecoveryCompleted(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
- dataRecoveryConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Properties related to data recovery mode behavior for this version.
- DataRecoveryConfig - Class in com.linkedin.venice.systemstore.schemas
- DataRecoveryConfig() - Constructor for class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
-
Default constructor.
- DataRecoveryConfig(CharSequence, Boolean, Integer) - Constructor for class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
-
All-args constructor.
- DataRecoveryEstimator - Class in com.linkedin.venice.datarecovery
-
DataRecoveryExecutor is the engine to run tasks in data recovery.
- DataRecoveryEstimator() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryEstimator
- DataRecoveryExecutor - Class in com.linkedin.venice.datarecovery
-
DataRecoveryExecutor is the engine to run tasks in data recovery.
- DataRecoveryExecutor() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryExecutor
- DataRecoveryManager - Class in com.linkedin.venice.controller.datarecovery
-
This class contains all the logics to: 1.
- DataRecoveryManager(VeniceHelixAdmin, Optional<ICProvider>, PubSubTopicRepository, ParticipantStoreClientsManager) - Constructor for class com.linkedin.venice.controller.datarecovery.DataRecoveryManager
- DataRecoveryMonitor - Class in com.linkedin.venice.datarecovery
- DataRecoveryMonitor() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryMonitor
- DataRecoveryParams(Set<String>) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryClient.DataRecoveryParams
- DataRecoveryRoutes - Class in com.linkedin.venice.controller.server
- DataRecoveryRoutes(boolean, Optional<DynamicAccessController>) - Constructor for class com.linkedin.venice.controller.server.DataRecoveryRoutes
- dataRecoverySourceFabric - Variable in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
-
The fabric name to be used as the source for data recovery.
- dataRecoverySourceVersionNumber - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- dataRecoverySourceVersionNumber - Variable in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
-
The store version number to be used as the source for data recovery.
- DataRecoveryTask - Class in com.linkedin.venice.datarecovery
-
A Task is wrapper class that designed to execute multiple commands in sequence.
- DataRecoveryTask(Command, DataRecoveryTask.TaskParams) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryTask
- DataRecoveryTask.TaskParams - Class in com.linkedin.venice.datarecovery
- DataRecoveryTask.TaskResult - Class in com.linkedin.venice.datarecovery
- DataRecoveryVersionConfig - Interface in com.linkedin.venice.meta
-
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
- DataRecoveryVersionConfigImpl - Class in com.linkedin.venice.meta
- DataRecoveryVersionConfigImpl(String, boolean, int) - Constructor for class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
- DataRecoveryWorker - Class in com.linkedin.venice.datarecovery
- DataRecoveryWorker() - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryWorker
- DataRecoveryWorker(int) - Constructor for class com.linkedin.venice.datarecovery.DataRecoveryWorker
- dataReplicationPolicy - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
-
Real-time Samza job data replication policy.
- dataReplicationPolicy - Variable in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
-
Real-time Samza job data replication policy, and default is 'NON_AGGREGATE'
- DataReplicationPolicy - Enum Class in com.linkedin.venice.meta
-
The data replication policy determines which fabric to use for sending real-time writes from clients and where to direct servers for real-time data consumption.
- DATASET_CHANGED - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- dataSource - Variable in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- DataValidationException - Exception in com.linkedin.venice.exceptions.validation
-
This class encompasses all error conditions which are related to the quality of the data consumed from Kafka.
- DataValidationException() - Constructor for exception com.linkedin.venice.exceptions.validation.DataValidationException
- DataValidationException(String, boolean) - Constructor for exception com.linkedin.venice.exceptions.validation.DataValidationException
- DataWriterAccumulators - Class in com.linkedin.venice.spark.datawriter.task
-
All the
AccumulatorV2
objects that are used in the Spark DataWriter jobs. - DataWriterAccumulators(SparkSession) - Constructor for class com.linkedin.venice.spark.datawriter.task.DataWriterAccumulators
- DataWriterComputeJob - Class in com.linkedin.venice.jobs
-
An abstraction for executing and monitoring a data writer compute job running on any batch compute engine
- DataWriterComputeJob() - Constructor for class com.linkedin.venice.jobs.DataWriterComputeJob
- DataWriterComputeJob.ConfigSetter - Interface in com.linkedin.venice.jobs
- dataWriterComputeJobClass - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- DataWriterMRJob - Class in com.linkedin.venice.hadoop.mapreduce.datawriter.jobs
-
The implementation of
DataWriterComputeJob
for MapReduce engine. - DataWriterMRJob() - Constructor for class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
- DataWriterSparkJob - Class in com.linkedin.venice.spark.datawriter.jobs
-
The default implementation of
AbstractDataWriterSparkJob
for Avro and Vson file input formats. - DataWriterSparkJob() - Constructor for class com.linkedin.venice.spark.datawriter.jobs.DataWriterSparkJob
- DataWriterTaskTracker - Interface in com.linkedin.venice.hadoop.task.datawriter
-
An interface to report and retrieve metrics related to data writer tasks.
- DATE - Enum constant in enum class com.linkedin.venice.schema.vson.VsonTypes
-
Deprecated.
- DATETIME - Enum constant in enum class com.linkedin.venice.Arg
- DAVINCI_CLIENT - Enum constant in enum class com.linkedin.venice.stats.ClientType
- DAVINCI_HEARTBEAT_REPORTED - Enum constant in enum class com.linkedin.venice.Arg
- DAVINCI_P2P_BLOB_TRANSFER_CLIENT_PORT - Static variable in class com.linkedin.venice.ConfigKeys
- DAVINCI_P2P_BLOB_TRANSFER_SERVER_PORT - Static variable in class com.linkedin.venice.ConfigKeys
- DAVINCI_PUSH_STATUS_CHECK_INTERVAL_IN_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
If the config value is non-negative, da-vinci client will batch push statues among all partitions into one single update events; DaVinciPushStatusUpdateTask will check the push status across all partitions in the same DaVinci node, and decide whether to send a status update event.
- DAVINCI_PUSH_STATUS_SCAN_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
- DAVINCI_PUSH_STATUS_SCAN_INTERVAL_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigKeys
- DAVINCI_PUSH_STATUS_SCAN_MAX_OFFLINE_INSTANCE_COUNT - Static variable in class com.linkedin.venice.ConfigKeys
- DAVINCI_PUSH_STATUS_SCAN_MAX_OFFLINE_INSTANCE_RATIO - Static variable in class com.linkedin.venice.ConfigKeys
- DAVINCI_PUSH_STATUS_SCAN_NO_REPORT_RETRY_MAX_ATTEMPTS - Static variable in class com.linkedin.venice.ConfigKeys
-
Max retry when not receiving any DaVinci status report.
- DAVINCI_PUSH_STATUS_SCAN_THREAD_NUMBER - Static variable in class com.linkedin.venice.ConfigKeys
- DAVINCI_PUSH_STATUS_STORE - Enum constant in enum class com.linkedin.venice.common.VeniceSystemStoreType
- DAVINCI_PUSH_STATUS_STORE_STR - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
- DaVinciBackend - Class in com.linkedin.davinci
- DaVinciBackend(ClientConfig, VeniceConfigLoader, Optional<Set<String>>, ICProvider, Optional<ObjectCacheConfig>, DaVinciRecordTransformerConfig) - Constructor for class com.linkedin.davinci.DaVinciBackend
- DaVinciBlobFinder - Class in com.linkedin.venice.blobtransfer
-
DvcBlobFinder discovers live DaVinci peer nodes to facilitate blob transfers necessary for bootstrapping the database
- DaVinciBlobFinder(ClientConfig) - Constructor for class com.linkedin.venice.blobtransfer.DaVinciBlobFinder
- DaVinciClient<K,
V> - Interface in com.linkedin.davinci.client -
Da Vinci Client to provide key-value lookups in embedded mode
- DaVinciClientFactory - Interface in com.linkedin.davinci.client.factory
- DaVinciConfig - Class in com.linkedin.davinci.client
- DaVinciConfig() - Constructor for class com.linkedin.davinci.client.DaVinciConfig
- daVinciConfigProvider() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- daVinciPushStatusStoreEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- daVinciPushStatusStoreEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Whether or not davinci push status store is enabled.
- DaVinciPushStatusUpdateTask - Class in com.linkedin.davinci.notifier
-
This is a scheduler for sending batching push status in DaVinci.
- DaVinciPushStatusUpdateTask(Version, long, PushStatusStoreWriter, Supplier<Boolean>) - Constructor for class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- DaVinciRecordTransformer<K,
V, O> - Class in com.linkedin.davinci.client -
This abstract class can be extended in order to transform records stored in the Da Vinci Client, or write to a custom storage of your choice.
- DaVinciRecordTransformer(int, Schema, Schema, Schema, DaVinciRecordTransformerConfig) - Constructor for class com.linkedin.davinci.client.DaVinciRecordTransformer
- DaVinciRecordTransformerBootstrappingChangelogConsumer(int, Schema, Schema, Schema, DaVinciRecordTransformerConfig) - Constructor for class com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl.DaVinciRecordTransformerBootstrappingChangelogConsumer
- DaVinciRecordTransformerConfig - Class in com.linkedin.davinci.client
-
Configuration class for
DaVinciRecordTransformer
, which is passed intoDaVinciConfig
. - DaVinciRecordTransformerConfig(DaVinciRecordTransformerConfig.Builder) - Constructor for class com.linkedin.davinci.client.DaVinciRecordTransformerConfig
- DaVinciRecordTransformerConfig.Builder - Class in com.linkedin.davinci.client
- DaVinciRecordTransformerFunctionalInterface - Interface in com.linkedin.davinci.client
-
This describes the implementation for the functional interface of
DaVinciRecordTransformer
- DaVinciRecordTransformerResult<O> - Class in com.linkedin.davinci.client
-
This class encapsulates the result of
DaVinciRecordTransformer.transform(com.linkedin.venice.utils.lazy.Lazy<K>, com.linkedin.venice.utils.lazy.Lazy<V>, int)
- DaVinciRecordTransformerResult(DaVinciRecordTransformerResult.Result) - Constructor for class com.linkedin.davinci.client.DaVinciRecordTransformerResult
-
Use this constructor if result is
DaVinciRecordTransformerResult.Result.SKIP
orDaVinciRecordTransformerResult.Result.UNCHANGED
- DaVinciRecordTransformerResult(DaVinciRecordTransformerResult.Result, O) - Constructor for class com.linkedin.davinci.client.DaVinciRecordTransformerResult
-
Use this constructor if result is
DaVinciRecordTransformerResult.Result.TRANSFORMED
- DaVinciRecordTransformerResult.Result - Enum Class in com.linkedin.davinci.client
- daVinciRecordTransformerStats - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- DaVinciRecordTransformerStats - Class in com.linkedin.davinci.stats
- DaVinciRecordTransformerStats() - Constructor for class com.linkedin.davinci.stats.DaVinciRecordTransformerStats
- DaVinciRecordTransformerStatsReporter - Class in com.linkedin.davinci.stats
-
This class is the reporting class for stats class
DaVinciRecordTransformerStats
Metrics reporting logics are registered intoMetricsRepository
here and send out to external metrics collection/visualization system. - DaVinciRecordTransformerStatsReporter(MetricsRepository, String, String) - Constructor for class com.linkedin.davinci.stats.DaVinciRecordTransformerStatsReporter
- DaVinciRecordTransformerStatsReporter.DaVinciRecordTransformerStatsGauge - Class in com.linkedin.davinci.stats
- DaVinciRecordTransformerUtility<K,
O> - Class in com.linkedin.davinci.client -
Utility class for
DaVinciRecordTransformer
. - DaVinciRecordTransformerUtility(DaVinciRecordTransformer, DaVinciRecordTransformerConfig) - Constructor for class com.linkedin.davinci.client.DaVinciRecordTransformerUtility
- DEAD - Enum constant in enum class com.linkedin.venice.pushstatushelper.PushStatusStoreReader.InstanceStatus
- DeadStoreStats - Interface in com.linkedin.venice.controller.stats
- DeadStoreStatsPreFetchTask - Class in com.linkedin.venice.controller
-
This task is responsible for pre-fetching dead store stats to then be leveraged by getDeadStores() method.
- DeadStoreStatsPreFetchTask(String, VeniceHelixAdmin, long) - Constructor for class com.linkedin.venice.controller.DeadStoreStatsPreFetchTask
- DEBUG - Enum constant in enum class com.linkedin.venice.Arg
- debugInfo - Variable in class com.linkedin.venice.kafka.protocol.ControlMessage
-
This metadata is for logging and traceability purposes.
- debugInfo - Variable in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
The debug info received as part of the last StartOfSegment ControlMessage.
- decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
- decode(ChannelHandlerContext, Http2StreamFrame, List<Object>) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
- decode(InputStream) - Method in class com.linkedin.venice.beam.consumer.PubSubMessageCoder
- decode(InputStream) - Method in class com.linkedin.venice.beam.consumer.VeniceCheckpointMark.Coder
- decode(InputStream) - Method in class com.linkedin.venice.beam.consumer.VeniceMessageCoder
- decode(CharSequence, Charset) - Static method in enum class com.linkedin.alpini.base.misc.URLCodec
-
Decodes a
application/x-www-form-urlencoded
string using a specific encoding scheme. - decode(String, Charset) - Static method in enum class com.linkedin.alpini.base.misc.URLCodec
-
Decodes a
application/x-www-form-urlencoded
string using a specific encoding scheme. - Decoder(int, int, int, boolean, int) - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Decoder
-
Creates a new instance with the specified parameters.
- decodeStringAndConvertToVeniceChangeCoordinate(PubSubPositionDeserializer, String) - Static method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
- decompress(byte[], int, int) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompress(byte[], int, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
- decompress(InputStream) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompress(InputStream) - Method in class com.linkedin.venice.compression.VeniceCompressor
- decompress(ByteBuffer) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompress(ByteBuffer) - Method in class com.linkedin.venice.compression.VeniceCompressor
- decompressAndPrependSchemaHeader(byte[], int, int, int) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompressAndPrependSchemaHeader(byte[], int, int, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
-
This method tries to decompress data and maybe prepend the schema header.
- decompressAndPrependSchemaHeaderInternal(byte[], int, int, int) - Method in class com.linkedin.venice.compression.GzipCompressor
- decompressAndPrependSchemaHeaderInternal(byte[], int, int, int) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompressAndPrependSchemaHeaderInternal(byte[], int, int, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
- decompressAndPrependSchemaHeaderInternal(byte[], int, int, int) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- decompressInternal(byte[], int, int) - Method in class com.linkedin.venice.compression.GzipCompressor
- decompressInternal(byte[], int, int) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompressInternal(byte[], int, int) - Method in class com.linkedin.venice.compression.VeniceCompressor
- decompressInternal(byte[], int, int) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- decompressInternal(InputStream) - Method in class com.linkedin.venice.compression.GzipCompressor
- decompressInternal(InputStream) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompressInternal(InputStream) - Method in class com.linkedin.venice.compression.VeniceCompressor
- decompressInternal(InputStream) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- decompressInternal(ByteBuffer) - Method in class com.linkedin.venice.compression.GzipCompressor
- decompressInternal(ByteBuffer) - Method in class com.linkedin.venice.compression.NoopCompressor
- decompressInternal(ByteBuffer) - Method in class com.linkedin.venice.compression.VeniceCompressor
- decompressInternal(ByteBuffer) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- decompressMultiGetContent(CompressionStrategy, ByteBuf) - Method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
-
Decompressing multi-get response in router side is a bit of overhead.
- decompressSingleGetContent(CompressionStrategy, ByteBuf) - Method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
- decorateResponse(Headers, Headers, Metrics) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
-
Modifies or replaces the task used to execute a runnable.
- decorateTask(Callable<V>, RunnableScheduledFuture<V>) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
-
Modifies or replaces the task used to execute a callable.
- decreaseConcurrentUserCount(BlobTransferPayload) - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Decrease the count of hosts using the snapshot
- decrementClientConnectionCount() - Method in class com.linkedin.venice.stats.ServerConnectionStats
- decrementRouterConnectionCount() - Method in class com.linkedin.venice.stats.ServerConnectionStats
- decrementThreadBlockedOnOfflineToDroppedTransitionCount() - Method in class com.linkedin.davinci.stats.ParticipantStateTransitionStats
- DeepCopyOffsetManager - Class in com.linkedin.venice.offsets
-
This class is used to systematically copy
OffsetRecord
instances rather than passing them as is. - DeepCopyOffsetManager(OffsetManager) - Constructor for class com.linkedin.venice.offsets.DeepCopyOffsetManager
- DeepCopyStorageMetadataService - Class in com.linkedin.venice.offsets
-
This class is used to systematically copy
OffsetRecord
instances rather than passing them as is. - DeepCopyStorageMetadataService(StorageMetadataService) - Constructor for class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
- DeepEqualsArrayList() - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
-
Deprecated.
- DeepEqualsArrayList(int) - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
-
Deprecated.
- DeepEqualsHashMap() - Constructor for class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsHashMap
-
Deprecated.
- DEFAULT - Enum constant in enum class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategyType
- DEFAULT - Enum constant in enum class com.linkedin.venice.partitioner.VenicePartitioner.VenicePartitionerType
- DEFAULT_BATCH_BYTES_SIZE - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_BATCH_GET_LIMIT - Static variable in interface com.linkedin.venice.meta.Store
- DEFAULT_BITSET_SIZE - Static variable in class com.linkedin.venice.utils.RedundantExceptionFilter
- DEFAULT_BUILDER - Static variable in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer
- DEFAULT_CHECK_SUM_TYPE - Static variable in class com.linkedin.venice.writer.VeniceWriter
-
Default checksum type.
- DEFAULT_CHUNK_SPLIT_THRESHOLD - Static variable in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- DEFAULT_CLOSE_TIMEOUT_MS - Static variable in class com.linkedin.venice.writer.VeniceWriter
-
This controls the Kafka producer's close timeout.
- DEFAULT_CLUSTER_DISCOVERY_D2_SERVICE_NAME - Static variable in class com.linkedin.venice.client.store.ClientConfig
- DEFAULT_CLUSTER_DISCOVERY_D2_SERVICE_NAME - Static variable in class com.linkedin.venice.router.RouterServer
- DEFAULT_COLUMN_FAMILY_INDEX - Static variable in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
- DEFAULT_COMPRESSION_DICTIONARY_SAMPLE_SIZE - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_COMPRESSION_METRIC_COLLECTION_ENABLED - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_CONN_WARMUP_TIMEOUT_IN_SECONDS_DEFAULT - Static variable in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- DEFAULT_CONTROLLER_ENABLE_REAL_TIME_TOPIC_VERSIONING - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_CONTROLLER_SSL_ENABLED - Static variable in class com.linkedin.venice.SSLConfig
- DEFAULT_D2_ZK_BASE_PATH - Static variable in class com.linkedin.venice.client.store.ClientConfig
- DEFAULT_DATA_REPLICATION_POLICY - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
- DEFAULT_DESERIALIZER - Static variable in class com.linkedin.venice.pubsub.PubSubPositionDeserializer
-
Note: The following default instance is only for convenience purposes until we've updated all the code to use pass the registry and resolver explicitly.
- DEFAULT_DOC - Static variable in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
-
Deprecated.
- DEFAULT_EXECUTION_ID - Static variable in class com.linkedin.venice.controllerapi.RepushJobResponse
- DEFAULT_EXTENDED_SCHEMA_VALIDITY_CHECK_ENABLED - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_FORMAT - Static variable in class com.linkedin.venice.RequestConstants
- DEFAULT_GUID_GENERATOR_IMPLEMENTATION - Static variable in class com.linkedin.venice.guid.GuidUtils
- DEFAULT_HELIX_OP_RETRY_COUNT - Static variable in class com.linkedin.venice.utils.HelixUtils
-
Retry 3 times for each helix operation in case of getting the error by default.
- DEFAULT_HYBRID_OFFSET_LAG_THRESHOLD - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
- DEFAULT_HYBRID_TIME_LAG_THRESHOLD - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
- DEFAULT_INSTANCE_GROUP_ID - Static variable in class com.linkedin.venice.helix.HelixInstanceConfigRepository
- DEFAULT_IS_DUPLICATED_KEY_ALLOWED - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_JOB_STATUS_IN_UNKNOWN_STATE_TIMEOUT_MS - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
The default total time we wait before failing a job if the job status stays in UNKNOWN state.
- DEFAULT_KAFKA_BATCH_SIZE - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
-
Default Kafka batch size and linger time for better producer performance during ingestion.
- DEFAULT_KAFKA_INPUT_MAX_RECORDS_PER_MAPPER - Static variable in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
-
The default max records per mapper, and if there are more records in one topic partition, it will be consumed by multiple mappers in parallel.
- DEFAULT_KAFKA_LINGER_MS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
- DEFAULT_KAFKA_MIN_LOG_COMPACTION_LAG_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
-
Default setting is that no log compaction should happen for hybrid store version topics if the messages are produced within 24 hours; otherwise servers could encounter MISSING data DIV errors for reprocessing jobs which could potentially generate lots of duplicate keys.
- DEFAULT_KAFKA_REPLICATION_FACTOR - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
- DEFAULT_KEY_FIELD_PROP - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_LAG_LOGGING_THREAD_SLEEP_INTERVAL_SECONDS - Static variable in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- DEFAULT_LEADER_METADATA_WRAPPER - Static variable in class com.linkedin.venice.writer.VeniceWriter
- DEFAULT_MAX_ATTEMPTS_WHEN_TOPIC_MISSING - Static variable in class com.linkedin.venice.writer.VeniceWriter
-
Default number of attempts when trying to produce to a Kafka topic and an exception is caught saying the topic is missing.
- DEFAULT_MAX_ELAPSED_TIME_FOR_SEGMENT_IN_MS - Static variable in class com.linkedin.venice.writer.VeniceWriter
-
Default elapsed time for a segment in milliseconds.
- DEFAULT_MAX_NUMBER_OF_PARTITIONS - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_MAX_RECORD_SIZE_BYTES - Static variable in class com.linkedin.venice.ConfigKeys
-
Config for the default value which is filled in when the store-level config
VeniceWriter.maxRecordSizeBytes
is left unset. - DEFAULT_MAX_RECORD_SIZE_BYTES_BACKFILL - Static variable in class com.linkedin.venice.ConfigConstants
- DEFAULT_MAX_SIZE_FOR_USER_PAYLOAD_PER_MESSAGE_IN_BYTES - Static variable in class com.linkedin.venice.writer.VeniceWriter
-
950 KB for user payload should be conservative enough.
- DEFAULT_MAXIMUM_ENTRY_COUNT - Static variable in class com.linkedin.venice.meta.NameRepository
- DEFAULT_MESSAGE - Static variable in exception com.linkedin.alpini.base.misc.Http2TooManyStreamsException
- DEFAULT_NAMESPACE - Static variable in class com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
-
Deprecated.
- DEFAULT_NO_REDUNDANT_EXCEPTION_DURATION_MS - Static variable in class com.linkedin.venice.utils.RedundantExceptionFilter
- DEFAULT_NUMBER_OF_PARTITION - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_NUMBER_OF_PARTITION_FOR_HYBRID - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_OFFLINE_PUSH_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_OFFSET_LAG - Static variable in class com.linkedin.venice.offsets.OffsetRecord
- DEFAULT_PARTITION_SIZE - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_PER_ROUTER_READ_QUOTA - Static variable in class com.linkedin.venice.VeniceConstants
-
Default per router max read quota; notice that this value is used in controller; the actual per router max read quota is defined as a router config "max.read.capacity".
- DEFAULT_POLL_STATUS_INTERVAL_MS - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_PUBSUB_SERIALIZER - Static variable in class com.linkedin.venice.pubsub.api.PubSubMessageSerializer
-
A default instance of
PubSubMessageSerializer
using defaultKafkaKeySerializer
andKafkaValueSerializer
. - DEFAULT_PUSH_JOB_USER_ERROR_CHECKPOINTS - Static variable in enum class com.linkedin.venice.PushJobCheckpoints
-
Default set checkpoints to define push job failures are user errors which can be overridden via controller config
ConfigKeys.PUSH_JOB_FAILURE_CHECKPOINTS_TO_DEFINE_USER_ERROR
- DEFAULT_PUSH_STATUS_STORE_HEARTBEAT_EXPIRATION_TIME_IN_SECONDS - Static variable in class com.linkedin.venice.ConfigConstants
- DEFAULT_RE_PUSH_REWIND_IN_SECONDS_OVERRIDE - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
The rewind override when performing re-push to prevent data loss; if the store has higher rewind config setting than 1 days, adopt the store config instead; otherwise, override the rewind config to 1 day if push job config doesn't try to override it.
- DEFAULT_READ_QUOTA - Static variable in class com.linkedin.venice.meta.AbstractStore
-
Default read quota 1800 QPS per node
- DEFAULT_READ_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
-
Fallback to remain compatible with the old config spelling.
- DEFAULT_REAL_TIME_TOPIC_NAME - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
- DEFAULT_RECEIVE_BUFFER_SIZE - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerConfig
- DEFAULT_REFRESH_INTERVAL_IN_SECONDS - Static variable in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- DEFAULT_REPAIR_THREAD_SLEEP_INTERVAL_SECONDS - Static variable in class com.linkedin.davinci.kafka.consumer.RemoteIngestionRepairService
- DEFAULT_REPLICA_FACTOR - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_REPLICATION_FACTOR - Static variable in class com.linkedin.venice.meta.AbstractStore
- DEFAULT_REPORTER_THREAD_SLEEP_INTERVAL_SECONDS - Static variable in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- DEFAULT_RETRY_LOAD_ATTEMPTS - Static variable in class com.linkedin.venice.helix.CachedResourceZkStateListener
- DEFAULT_RETRY_LOAD_INTERVAL_IN_MS - Static variable in class com.linkedin.venice.helix.CachedResourceZkStateListener
- DEFAULT_REWIND_TIME_IN_SECONDS - Static variable in class com.linkedin.venice.meta.HybridStoreConfigImpl
- DEFAULT_ROUTING_STRATEGY - Static variable in class com.linkedin.venice.ConfigKeys
- DEFAULT_RT_RETENTION_TIME - Static variable in interface com.linkedin.venice.meta.Store
- DEFAULT_RT_VERSION_NUMBER - Static variable in interface com.linkedin.venice.meta.Version
- DEFAULT_SCHEMA - Static variable in class com.linkedin.venice.spark.SparkConstants
- DEFAULT_SCHEMA_CREATION_COMPATIBILITY_TYPE - Static variable in class com.linkedin.venice.schema.SchemaEntry
- DEFAULT_SCHEMA_REFRESH_PERIOD - Static variable in class com.linkedin.venice.client.store.ClientConfig
- DEFAULT_SCHEMA_WITH_PARTITION - Static variable in class com.linkedin.venice.spark.SparkConstants
- DEFAULT_SEND_MESSAGE_TIME_OUT - Static variable in class com.linkedin.venice.helix.HelixStatusMessageChannel
- DEFAULT_SERVER_KAFKA_FETCH_QUOTA_RECORDS_PER_SECOND - Static variable in class com.linkedin.venice.meta.LiveClusterConfig
- DEFAULT_SNAPSHOT_CLEANUP_INTERVAL_IN_MINS - Static variable in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
- DEFAULT_SPARK_CLUSTER - Static variable in class com.linkedin.venice.spark.SparkConstants
- DEFAULT_SSL_ENABLED - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_SSL_FACTORY_CLASS_NAME - Static variable in class com.linkedin.venice.VeniceConstants
-
The default SSL factory class name; this class is mostly used in test cases; products that uses Venice lib should override the SSL factory class.
- DEFAULT_STALE_HEARTBEAT_LOG_THRESHOLD_MILLIS - Static variable in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- DEFAULT_STORAGE_QUOTA - Static variable in class com.linkedin.venice.meta.AbstractStore
-
Default storage quota 20GB
- DEFAULT_STORE_OWNER - Static variable in class com.linkedin.venice.controller.server.StoreRequestHandler
- DEFAULT_STORE_QUOTA_TIME_WINDOW - Static variable in class com.linkedin.venice.router.throttle.ReadRequestThrottler
- DEFAULT_TERM_ID - Static variable in class com.linkedin.venice.writer.VeniceWriter
- DEFAULT_TIMESTAMP_FIELD_PROP - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_TOPIC_RETENTION_POLICY_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
- DEFAULT_UPSTREAM_KAFKA_CLUSTER_ID - Static variable in class com.linkedin.venice.writer.VeniceWriter
- DEFAULT_UPSTREAM_OFFSET - Static variable in class com.linkedin.venice.writer.VeniceWriter
-
The default value of the "upstreamOffset" field in avro record
LeaderMetadata
. - DEFAULT_UPSTREAM_PUBSUB_POSITION - Static variable in class com.linkedin.venice.writer.VeniceWriter
- DEFAULT_USER_DATA_RECORD_COUNT - Static variable in class com.linkedin.venice.utils.TestWriteUtils
- DEFAULT_USER_DATA_VALUE_PREFIX - Static variable in class com.linkedin.venice.utils.TestWriteUtils
- DEFAULT_USER_SYSTEM_STORE_PARTITION_COUNT - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
- DEFAULT_USER_SYSTEM_STORE_UPDATE_QUERY_PARAMS - Static variable in class com.linkedin.venice.common.VeniceSystemStoreUtils
- DEFAULT_VALUE_FIELD_PROP - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DEFAULT_ZK_TIMEOUT_MS - Static variable in class com.linkedin.venice.client.store.ClientConfig
- DefaultAsyncFuture<T> - Class in com.linkedin.alpini.base.concurrency.impl
-
An implementation of
AsyncFuture
where much of the implementation is based upon netty'sorg.jboss.netty.channel.DefaultChannelFuture
. - DefaultAsyncFuture(boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
-
Creates a new instance.
- DefaultAsyncFutureTask<T> - Class in com.linkedin.alpini.base.concurrency.impl
- DefaultAsyncFutureTask(Callable<T>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
-
Wrap a callable in an AsyncFuture.
- DefaultAsyncFutureTask(Executor, Callable<T>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
- DefaultAsyncFutureTask(ExecutorService, Callable<T>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFutureTask
-
Wrap a callable in an AsyncFuture and then submit it to be executed on the provided ExecutorService.
- DefaultCollectingAsyncFuture<V> - Class in com.linkedin.alpini.base.concurrency.impl
-
A specialised instance of @{link AsyncFuture} for collecting the results of one or more futures of lists into a single list.
- DefaultCollectingAsyncFuture(List<AsyncFuture<List<V>>>, boolean) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultCollectingAsyncFuture
-
Creates a new instance.
- DefaultCollectingAsyncFuture(List<AsyncFuture<List<V>>>, boolean, Function<List<V>, List<V>>) - Constructor for class com.linkedin.alpini.base.concurrency.impl.DefaultCollectingAsyncFuture
-
Creates a new instance.
- DefaultConsumerPoolStrategy() - Constructor for class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.DefaultConsumerPoolStrategy
- defaultConsumerService - Variable in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.DefaultConsumerPoolStrategy
- defaultFactory() - Static method in class org.apache.avro.io.OptimizedBinaryDecoderFactory
- defaultGenericClientConfig(String) - Static method in class com.linkedin.venice.client.store.ClientConfig
- DefaultHadoopJobClientProvider - Class in com.linkedin.venice.hadoop.mapreduce.engine
- DefaultHadoopJobClientProvider() - Constructor for class com.linkedin.venice.hadoop.mapreduce.engine.DefaultHadoopJobClientProvider
- DefaultIdentityParser - Class in com.linkedin.venice.authorization
- DefaultIdentityParser() - Constructor for class com.linkedin.venice.authorization.DefaultIdentityParser
- DefaultIngestionBackend - Class in com.linkedin.davinci.ingestion
-
The default ingestion backend implementation.
- DefaultIngestionBackend(StorageMetadataService, KafkaStoreIngestionService, StorageService, BlobTransferManager, VeniceServerConfig) - Constructor for class com.linkedin.davinci.ingestion.DefaultIngestionBackend
- DefaultInputDataInfoProvider - Class in com.linkedin.venice.hadoop
- DefaultInputDataInfoProvider(PushJobSetting, VeniceProperties) - Constructor for class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
- DefaultJobClientWrapper - Class in com.linkedin.venice.hadoop.mapreduce.engine
- DefaultJobClientWrapper() - Constructor for class com.linkedin.venice.hadoop.mapreduce.engine.DefaultJobClientWrapper
- DefaultLeaderMetadata(CharSequence) - Constructor for class com.linkedin.venice.writer.VeniceWriter.DefaultLeaderMetadata
- DefaultLingeringStoreVersionChecker - Class in com.linkedin.venice.controller.lingeringjob
- DefaultLingeringStoreVersionChecker() - Constructor for class com.linkedin.venice.controller.lingeringjob.DefaultLingeringStoreVersionChecker
- defaultMode - Static variable in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
- DefaultPubSubMessage - Interface in com.linkedin.venice.pubsub.api
-
A default implementation of
PubSubMessage
that represents a message in a pub-sub system with aKafkaKey
as the key, aKafkaMessageEnvelope
as the value, and aPubSubPosition
to track the message's offset within the topic-partition. - DefaultPushJobHeartbeatSenderFactory - Class in com.linkedin.venice.heartbeat
- DefaultPushJobHeartbeatSenderFactory() - Constructor for class com.linkedin.venice.heartbeat.DefaultPushJobHeartbeatSenderFactory
- defaultReadyToServeChecker - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- DefaultSerializer - Class in com.linkedin.venice.serialization
-
Default Kafka VeniceKafkaSerializer
- DefaultSerializer() - Constructor for class com.linkedin.venice.serialization.DefaultSerializer
- defaultSpecificClientConfig(String, Class<V>) - Static method in class com.linkedin.venice.client.store.ClientConfig
- DefaultSSLFactory - Class in com.linkedin.venice.security
-
Cloned from
com.linkedin.security.ssl.access.control.SSLEngineComponentFactoryImpl
; Changes: 1. - DefaultSSLFactory(SSLConfig) - Constructor for class com.linkedin.venice.security.DefaultSSLFactory
- DefaultSSLFactory(Properties) - Constructor for class com.linkedin.venice.security.DefaultSSLFactory
- DefaultSupersetSchemaGenerator - Class in com.linkedin.venice.controller.supersetschema
- DefaultSupersetSchemaGenerator() - Constructor for class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
- defaultThreadFactory() - Static method in enum class com.linkedin.alpini.base.concurrency.Executors
-
Returns a default thread factory used to create new threads.
- defaultTimeoutMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
- DefaultVenicePartitioner - Class in com.linkedin.venice.partitioner
-
Default implementation of the
VenicePartitioner
class. - DefaultVenicePartitioner() - Constructor for class com.linkedin.venice.partitioner.DefaultVenicePartitioner
- DefaultVenicePartitioner(VeniceProperties) - Constructor for class com.linkedin.venice.partitioner.DefaultVenicePartitioner
- DefaultVenicePartitioner(VeniceProperties, Schema) - Constructor for class com.linkedin.venice.partitioner.DefaultVenicePartitioner
- defaultVPJProps(String, String, String, Map<String, String>) - Static method in class com.linkedin.venice.utils.TestWriteUtils
- defaultVPJPropsWithD2Routing(String, String, Map<String, String>, String, String, String, String, Map<String, String>) - Static method in class com.linkedin.venice.utils.TestWriteUtils
- defaultVsonGenericClientConfig(String) - Static method in class com.linkedin.venice.client.store.ClientConfig
-
Deprecated.
- DEFER_VERSION_SWAP - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DEFER_VERSION_SWAP - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
-
This config is a boolean which waits for an external signal to trigger version swap after buffer replay is complete.
- deferred(boolean) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
-
Create a new default deferred future.
- DEFERRED_VERSION_SWAP_BUFFER_TIME - Static variable in class com.linkedin.venice.ConfigKeys
-
Specifies after how long the wait time has passed before emitting a stalled version swap metric.
- DeferredVersionSwapService - Class in com.linkedin.venice.controller
-
This service is in charge of swapping to a new version after a specified wait time in the remaining regions of a target region push if enabled.
- DeferredVersionSwapService(VeniceParentHelixAdmin, VeniceControllerMultiClusterConfig, DeferredVersionSwapStats) - Constructor for class com.linkedin.venice.controller.DeferredVersionSwapService
- DeferredVersionSwapStats - Class in com.linkedin.venice.controller.stats
- DeferredVersionSwapStats(MetricsRepository) - Constructor for class com.linkedin.venice.controller.stats.DeferredVersionSwapStats
- deferredWrite - Variable in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
-
Whether the input is sorted or not.
- deferredWrite - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Whether deferred write mode is enabled currently
- deferVersionSwap - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- deferVersionSwap - Variable in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
flag that informs venice controller to defer marking this version as the serving version after instances report ready to serve.
- definition - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
- DEGRADED - Enum constant in enum class com.linkedin.venice.meta.StoreStatus
- DELAY_CONSTRAINT - Enum constant in enum class com.linkedin.venice.stats.dimensions.RequestRetryAbortReason
- DELAY_EXECUTION - Static variable in class com.linkedin.venice.RequestConstants
- DELAY_TO_REBALANCE_MS - Static variable in class com.linkedin.venice.ConfigKeys
- delayFactor - Variable in class com.linkedin.venice.controller.kafka.TopicCleanupService
- delegate - Variable in class com.linkedin.venice.meta.ReadOnlyStore
- delegate - Variable in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- delegateConsumerRecord(PubSubMessageProcessedResultWrapper, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- delegateConsumerRecord(PubSubMessageProcessedResultWrapper, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
-
The goal of this function is to possibly produce the incoming kafka message consumed from local VT, remote VT, RT or SR topic to local VT if needed.
- delegateConsumerRecord(PubSubMessageProcessedResultWrapper, int, String, int, long, long) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- delegateKafkaConsumerServiceFor(PartitionReplicaIngestionContext) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.AAOrWCLeaderConsumerPoolStrategy
- delegateKafkaConsumerServiceFor(PartitionReplicaIngestionContext) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategy
- delegateKafkaConsumerServiceFor(PartitionReplicaIngestionContext) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.CurrentVersionConsumerPoolStrategy
- delegateKafkaConsumerServiceFor(PartitionReplicaIngestionContext) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.DefaultConsumerPoolStrategy
- DelegatingAvroGenericDaVinciClient<K,
V> - Class in com.linkedin.davinci.client -
Delegating layer for
DaVinciClient
. - DelegatingAvroGenericDaVinciClient(AvroGenericDaVinciClient<K, V>) - Constructor for class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- DelegatingAvroStoreClient<K,
V> - Class in com.linkedin.venice.fastclient -
Inside Fast-Client, we choose to use n-tier architecture style to build a pipeline to separate different types of logic in different layer.
- DelegatingAvroStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- DelegatingClusterLeaderInitializationRoutine - Class in com.linkedin.venice.controller.init
- DelegatingClusterLeaderInitializationRoutine() - Constructor for class com.linkedin.venice.controller.init.DelegatingClusterLeaderInitializationRoutine
- DelegatingStorageEngine<P extends AbstractStoragePartition> - Class in com.linkedin.davinci.store
- DelegatingStorageEngine(StorageEngine<P>) - Constructor for class com.linkedin.davinci.store.DelegatingStorageEngine
- DelegatingStoreClient<K,
V> - Class in com.linkedin.venice.client.store - DelegatingStoreClient(InternalAvroStoreClient<K, V>) - Constructor for class com.linkedin.venice.client.store.DelegatingStoreClient
- DelegatingTrackingCallback<K,
V> - Class in com.linkedin.venice.client.store.streaming - DelegatingTrackingCallback(StreamingCallback<K, V>) - Constructor for class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
- delete() - Method in class com.linkedin.davinci.config.StoreBackendConfig
- delete(byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Delete a key from the partition database
- delete(byte[]) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- delete(byte[]) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- delete(byte[]) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- delete(byte[]) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- delete(byte[], PubSubProducerCallback, LeaderMetadataWrapper, long, DeleteMetadata, ChunkedValueManifest, ChunkedValueManifest, int) - Method in class com.linkedin.venice.writer.VeniceWriter
- delete(int, byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- delete(int, byte[]) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- delete(int, byte[]) - Method in interface com.linkedin.davinci.store.StorageEngine
- delete(ValueAndRmd<ByteBuffer>, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeByteBuffer
- delete(ValueAndRmd<GenericRecord>, long, int, long, int) - Method in class com.linkedin.davinci.replication.merge.MergeGenericRecord
- delete(ValueAndRmd<T>, long, int, long, int) - Method in interface com.linkedin.davinci.replication.merge.Merge
- delete(KafkaKey, KafkaMessageEnvelope, PubSubProducerCallback, int, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
-
DIV pass-through mode for delete
- delete(Lazy<ByteBuffer>, RmdWithValueSchemaId, long, long, int, int) - Method in class com.linkedin.davinci.replication.merge.MergeConflictResolver
-
Perform conflict resolution when the incoming operation is a DELETE operation.
- delete(Object) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
- delete(K, long, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.VeniceWriter
-
Execute a standard "delete" on the key.
- delete(K, PubSubProducerCallback) - Method in class com.linkedin.venice.writer.VeniceWriter
-
Execute a standard "delete" on the key.
- delete(K, PubSubProducerCallback, DeleteMetadata) - Method in class com.linkedin.venice.hadoop.task.datawriter.CompositeVeniceWriter
-
In VPJ, only re-push can trigger this function.
- delete(K, PubSubProducerCallback, DeleteMetadata) - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
- delete(K, PubSubProducerCallback, DeleteMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
- delete(K, PubSubProducerCallback, LeaderMetadataWrapper) - Method in class com.linkedin.venice.writer.VeniceWriter
-
Execute a standard "delete" on the key.
- delete(K, PubSubProducerCallback, LeaderMetadataWrapper, long) - Method in class com.linkedin.venice.writer.VeniceWriter
-
Execute a standard "delete" on the key.
- delete(K, PubSubProducerCallback, LeaderMetadataWrapper, long, DeleteMetadata, ChunkedValueManifest, ChunkedValueManifest) - Method in class com.linkedin.venice.writer.ComplexVeniceWriter
- delete(K, PubSubProducerCallback, LeaderMetadataWrapper, long, DeleteMetadata, ChunkedValueManifest, ChunkedValueManifest) - Method in class com.linkedin.venice.writer.VeniceWriter
-
Execute a standard "delete" on the key.
- delete(K, PubSubProducerCallback, LeaderMetadataWrapper, DeleteMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
-
Execute a standard "delete" on the key.
- Delete - Class in com.linkedin.venice.kafka.protocol
-
Delete payloads contain fields related to replication metadata of the record.
- Delete() - Constructor for class com.linkedin.venice.kafka.protocol.Delete
-
Default constructor.
- Delete(Integer, Integer, ByteBuffer) - Constructor for class com.linkedin.venice.kafka.protocol.Delete
-
All-args constructor.
- DELETE - Enum constant in enum class com.linkedin.venice.authorization.Method
- DELETE - Enum constant in enum class com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
- DELETE - Enum constant in enum class com.linkedin.venice.kafka.protocol.enums.MessageType
- DELETE_ACL - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- DELETE_ALL_VERSIONS - Enum constant in enum class com.linkedin.venice.Command
- DELETE_ALL_VERSIONS - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DELETE_ALL_VERSIONS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- DELETE_KAFKA_TOPIC - Enum constant in enum class com.linkedin.venice.Command
- DELETE_KAFKA_TOPIC - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- DELETE_OLD_VERSION - Enum constant in enum class com.linkedin.venice.Command
- DELETE_OLD_VERSION - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DELETE_OLD_VERSION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- DELETE_ON_NEW_PUSH_START - Enum constant in enum class com.linkedin.venice.meta.BackupStrategy
-
Delete versions on SN (including kafka and metadata) to preserve only (numVersionsToPreserve-1) backup versions on new push start.
- DELETE_STORAGE_PERSONA - Enum constant in enum class com.linkedin.venice.Command
- DELETE_STORAGE_PERSONA - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DELETE_STORAGE_PERSONA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- DELETE_STORE - Enum constant in enum class com.linkedin.venice.Command
- DELETE_STORE - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DELETE_STORE - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- DELETE_STORE_ACL - Enum constant in enum class com.linkedin.venice.Command
- DELETE_UNUSED_VALUE_SCHEMA - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DELETE_UNUSED_VALUE_SCHEMAS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- deleteAclForStore(Admin, StoreRequestHandler) - Method in class com.linkedin.venice.controller.server.CreateStore
- deleteAclForStore(DeleteAclForStoreGrpcRequest) - Method in class com.linkedin.venice.controller.server.StoreRequestHandler
- deleteAclForStore(DeleteAclForStoreGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceBlockingStub
- deleteAclForStore(DeleteAclForStoreGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceFutureStub
- deleteAclForStore(DeleteAclForStoreGrpcRequest, StreamObserver<DeleteAclForStoreGrpcResponse>) - Method in class com.linkedin.venice.controller.grpc.server.StoreGrpcServiceImpl
- deleteAclForStore(DeleteAclForStoreGrpcRequest, StreamObserver<DeleteAclForStoreGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.AsyncService
- deleteAclForStore(DeleteAclForStoreGrpcRequest, StreamObserver<DeleteAclForStoreGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceStub
- deleteAclForStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- deleteAclForStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Delete the current set of ACL provisioned for a venice store and its associated kafka topic.
- deleteAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- deleteAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- DeleteAclForStoreGrpcRequest - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- DeleteAclForStoreGrpcRequest.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- DeleteAclForStoreGrpcRequestOrBuilder - Interface in com.linkedin.venice.protocols.controller
- DeleteAclForStoreGrpcResponse - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- DeleteAclForStoreGrpcResponse.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- DeleteAclForStoreGrpcResponseOrBuilder - Interface in com.linkedin.venice.protocols.controller
- deleteAclsForStore(Store, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Deletes the acls associated with a store
- deleteAllVersions(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- deleteAllVersions(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- DeleteAllVersions - Class in com.linkedin.venice.controller.kafka.protocol.admin
- DeleteAllVersions() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
-
Default constructor.
- DeleteAllVersions(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
-
All-args constructor.
- deleteAllVersionsInStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Delete all of venice versions in given store(including venice resource, kafka topic, offline pushs and all related resources).
- deleteAllVersionsInStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- deleteAllVersionsInStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- deleteConfig(String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
- deleteConfigs() - Method in class com.linkedin.venice.helix.HelixReadWriteLiveClusterConfigRepository
- deleteConfigs() - Method in interface com.linkedin.venice.meta.ReadWriteLiveClusterConfigRepository
-
Delete all live cluster configs
- DELETED_ELEM_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- DELETED_ELEM_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- DELETED_ELEM_TS_FIELD_NAME - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- DELETED_ELEM_TS_FIELD_POS - Static variable in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- DELETED_TS - Variable in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
-
If the current record is a PUT, this field will be null; if it's a DELETE, this field will be the offset of the record in Kafka
- deleteDeprecatedChunk(byte[], int, PubSubProducerCallback, LeaderMetadataWrapper, DeleteMetadata) - Method in class com.linkedin.venice.writer.VeniceWriter
-
This method produces a DELETE request to a deprecated chunk key.
- deleteDirectory(File) - Static method in class com.linkedin.venice.utils.TestUtils
- deleteFilesInDirectory(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- deleteHelixResource(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- deleteHelixResource(String, String) - Method in interface com.linkedin.venice.meta.StoreCleaner
-
This purpose of the function is to delete the given resource from the Helix cluster.
- deleteKafkaTopic(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- deleteKafkaTopic(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- DeleteMetadata - Class in com.linkedin.venice.writer
-
This is a simple container class to hold replication metadata related fields together to be passed on to the Delete api in VeniceWriter
VeniceWriter#delete(Object, Callback, LeaderMetadataWrapper, long, Optional)
. - DeleteMetadata(int, int, ByteBuffer) - Constructor for class com.linkedin.venice.writer.DeleteMetadata
- deleteOfflinePushStatusAndItsPartitionStatuses(String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
- deleteOfflinePushStatusAndItsPartitionStatuses(String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
-
Delete offline push and its partition statuses from persistent storage.
- deleteOldVersion(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- DeleteOldVersion - Class in com.linkedin.venice.controller.kafka.protocol.admin
- DeleteOldVersion() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
-
Default constructor.
- DeleteOldVersion(CharSequence, CharSequence, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
-
All-args constructor.
- deleteOldVersionInStore(String, String, int) - Method in interface com.linkedin.venice.controller.Admin
-
Delete the given version from the store.
- deleteOldVersionInStore(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- deleteOldVersionInStore(String, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- deleteOldVersions(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- deleteOneStoreVersion(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Delete version from cluster, removing all related resources
- deleteOneStoreVersion(String, String, int) - Method in interface com.linkedin.venice.meta.StoreCleaner
- deleteParticipantStoreKillMessage(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Compose a
ParticipantMessageKey
message and execute a delete operation on the key to the cluster's participant store. - deletePartitionDir(String, String, int, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
-
Deletes the files associated with the specified store, version, and partition.
- deletePartitionIncrementalPushStatus(String, int, String, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
-
N.B.: Currently used by tests only.
- deletePersona(StoragePersona) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
- deletePersona(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
-
Deletes the persona with the given name.
- deletePersona(String) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
- deleteProcessor(Schema) - Static method in class com.linkedin.venice.sql.AvroToSQL
- deletePushStatus(String, int, Optional<String>, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreWriter
- deleteRecord(GenericRecord, GenericRecord, long, int) - Method in interface com.linkedin.davinci.schema.merge.MergeRecordHelper
- deleteRecord(GenericRecord, GenericRecord, long, int) - Method in class com.linkedin.davinci.schema.merge.CollectionTimestampMergeRecordHelper
-
Note that a whole record deletion could result in partial deletion (one or multiple fields get deleted).
- deleteRecordField(GenericRecord, GenericRecord, Schema.Field, long, int) - Method in class com.linkedin.davinci.schema.merge.CollectionTimestampMergeRecordHelper
- deleteReplicaStatus(HelixPartitionState, String, String) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
- deleteReplicaStatus(String, int) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
-
When a replica is gone from an instance due to partition movement or resource drop, we need to call this delete function to explicitly delete the customized state for that replica.
- deleteStatement(String, Schema) - Static method in class com.linkedin.venice.sql.AvroToSQL
- deleteStoragePersona(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
- deleteStoragePersona(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- deleteStoragePersona(String, String) - Method in interface com.linkedin.venice.controller.Admin
- deleteStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- deleteStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Deletes the persona with the given name.
- DeleteStoragePersona - Class in com.linkedin.venice.controller.kafka.protocol.admin
- DeleteStoragePersona() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
-
Default constructor.
- DeleteStoragePersona(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
-
All-args constructor.
- deleteStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- deleteStore(String) - Method in class com.linkedin.davinci.DaVinciBackend
- deleteStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- deleteStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
- deleteStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepositoryAdapter
-
This function only be used to delete regular venice store, and the system store is bundled with regular venice store.
- deleteStore(String) - Method in interface com.linkedin.venice.meta.ReadWriteStoreRepository
-
Delete store from repository.
- deleteStore(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- deleteStore(String, String, boolean, int, boolean) - Method in interface com.linkedin.venice.controller.Admin
-
Delete the entire store including both metadata and real user's data.
- deleteStore(String, String, boolean, int, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
This method will delete store data, metadata, version and rt topics One exception is for stores with isMigrating flag set.
- deleteStore(String, String, boolean, int, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Delete a store by sending
DELETE_STORE
admin message to the Kafka admin topic and clearing all ACLs and release resource for the target store from authorize service. - deleteStore(String, String, int, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- DeleteStore - Class in com.linkedin.venice.controller.kafka.protocol.admin
- DeleteStore() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
-
Default constructor.
- DeleteStore(CharSequence, CharSequence, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
-
All-args constructor.
- deleteSystemStore(VeniceHelixAdmin, ReadWriteStoreRepository, PushMonitorDelegator, String, String, boolean, MetaStoreWriter, Logger) - Static method in class com.linkedin.venice.controller.UserSystemStoreLifeCycleHelper
- deleteTopic(PubSubTopic, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
-
Delete a given topic.
- deleteTopic(PubSubTopic, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Delete a given topic.
- deleteTopic(PubSubTopic, Duration) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- DeleteUnusedValueSchemas - Class in com.linkedin.venice.controller.kafka.protocol.admin
- DeleteUnusedValueSchemas() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
-
Default constructor.
- DeleteUnusedValueSchemas(CharSequence, CharSequence, List<Integer>) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
-
All-args constructor.
- deleteValueSchema(SchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
- deleteValueSchemas(String, String, Set<Integer>) - Method in interface com.linkedin.venice.controller.Admin
-
Deletes a store's values schema with ids `except` the ids passed in the argument inuseValueSchemaIds
- deleteValueSchemas(String, String, Set<Integer>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- deleteValueSchemas(String, String, Set<Integer>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- deleteValueSchemas(String, List<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- deleteVersion(int) - Method in class com.linkedin.venice.meta.AbstractStore
- deleteVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- deleteVersion(int) - Method in interface com.linkedin.venice.meta.Store
- deleteWithReplicationMetadata(byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
This API deletes a record from RocksDB but updates the metadata in ByteBuffer format and puts it into RocksDB.
- deleteWithReplicationMetadata(byte[], byte[]) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
-
This API deletes a record from RocksDB but updates the metadata in ByteBuffer format and puts it into RocksDB.
- deleteWithReplicationMetadata(int, byte[], byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- deleteWithReplicationMetadata(int, byte[], byte[]) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- deleteWithReplicationMetadata(int, byte[], byte[]) - Method in interface com.linkedin.davinci.store.StorageEngine
- deleteWithValueLevelTimestamp(long, long, long, int, ValueAndRmd<GenericRecord>) - Method in class com.linkedin.davinci.replication.merge.MergeGenericRecord
- deleting - Variable in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
-
Is the store undergoing deletion.
- DELIMITER - Static variable in class com.linkedin.venice.stats.AbstractVeniceStats
- Delta() - Constructor for class com.linkedin.alpini.router.monitoring.ScatterGatherStats.Delta
- DEMOTE_TO_FOLLOWER - Enum constant in enum class com.linkedin.davinci.store.StoragePartitionAdjustmentTrigger
- demoteToStandby(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- demoteToStandby(VeniceStoreVersionConfig, int, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
- demoteToStandby(PubSubTopicPartition, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- demoteToStandby(PubSubTopicPartition, LeaderFollowerPartitionStateModel.LeaderSessionIdChecker) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- DENY - Enum constant in enum class com.linkedin.venice.authorization.Permission
- DEPLOYMENT_ID - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
- DEPRECATED_TOPIC_MAX_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
This config is to indicate the max retention policy we have setup for deprecated jobs currently and in the past.
- DEPRECATED_TOPIC_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
The retention policy for deprecated topics, which includes topics for both failed jobs and retired store versions.
- dequalifyClassName(String) - Static method in class com.linkedin.venice.utils.TestUtils
- deregister() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- deregister(ChannelPromise) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- deregisterPartition(String) - Method in class com.linkedin.davinci.stats.RocksDBMemoryStats
- DERIVED_SCHEMA - Enum constant in enum class com.linkedin.venice.Arg
- DERIVED_SCHEMA - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DERIVED_SCHEMA_CREATION - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DERIVED_SCHEMA_ID - Enum constant in enum class com.linkedin.venice.Arg
- DERIVED_SCHEMA_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DERIVED_SCHEMA_ID_PROP - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- DerivedSchemaCreation - Class in com.linkedin.venice.controller.kafka.protocol.admin
- DerivedSchemaCreation() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
-
Default constructor.
- DerivedSchemaCreation(CharSequence, CharSequence, SchemaMeta, Integer, Integer) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
-
All-args constructor.
- DerivedSchemaEntry - Class in com.linkedin.venice.schema.writecompute
-
Derived schemas are designed for write compute operations.
- DerivedSchemaEntry(int, int, byte[]) - Constructor for class com.linkedin.venice.schema.writecompute.DerivedSchemaEntry
- DerivedSchemaEntry(int, int, String) - Constructor for class com.linkedin.venice.schema.writecompute.DerivedSchemaEntry
- DerivedSchemaEntry(int, int, Schema) - Constructor for class com.linkedin.venice.schema.writecompute.DerivedSchemaEntry
- DerivedSchemaEntrySerializer - Class in com.linkedin.venice.helix
-
This class is registered in ZKClient to handle derive schema serialization.
- DerivedSchemaEntrySerializer() - Constructor for class com.linkedin.venice.helix.DerivedSchemaEntrySerializer
- derivedSchemaId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
- derivedSchemaId - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- descendingIterator() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
-
Returns an iterator over the elements in reverse sequential order.
- DESCRIBE_STORE - Enum constant in enum class com.linkedin.venice.Command
- DESCRIBE_STORES - Enum constant in enum class com.linkedin.venice.Command
- describeAcls(Resource) - Method in interface com.linkedin.venice.authorization.AuthorizerService
-
Return a list of existing AceEntries present for the given resource.
- describeAcls(Resource) - Method in class com.linkedin.venice.controller.MockVeniceAuthorizer
- DESCRIPTION_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
- deserializationExecutor - Variable in class com.linkedin.venice.client.store.deserialization.BatchDeserializer
- deserialize(byte[]) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
- deserialize(byte[]) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserialize(byte[]) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserialize(byte[]) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserialize(byte[], int) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
- deserialize(byte[], int, SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.controller.kafka.consumer.StringToLongMapJSONSerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.controller.migration.MigrationPushStrategyJSONSerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.helix.AbstractSchemaEntrySerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.helix.HelixAdapterSerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.helix.SchemaEntrySerializer
-
This function will extract schema from file path, and schema content from ZNode data.
- deserialize(byte[], String) - Method in class com.linkedin.venice.helix.StoreJSONSerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.helix.SystemStoreJSONSerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.helix.VeniceJsonSerializer
- deserialize(byte[], String) - Method in class com.linkedin.venice.meta.SimpleStringSerializer
- deserialize(byte[], String) - Method in interface com.linkedin.venice.meta.VeniceSerializer
- deserialize(byte[], Supplier<Schema>, SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
- deserialize(byte[], SPECIFIC_RECORD) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
- deserialize(PubSubTopicPartition, byte[], byte[], PubSubMessageHeaders, PubSubPosition, Long) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
-
Deserialize a message from the pubsub specific message format to PubSubMessage.
- deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
-
Create an object from an array of bytes This method is used by the Kafka consumer.
- deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
- deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.DefaultSerializer
- deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.KafkaKeySerializer
- deserialize(String, byte[]) - Method in class com.linkedin.venice.serialization.StringSerializer
- deserialize(String, byte[]) - Method in interface com.linkedin.venice.serialization.VeniceKafkaSerializer
-
Create an object from an array of bytes
- deserialize(ByteBuffer) - Method in class com.linkedin.venice.serialization.avro.VeniceAvroKafkaSerializer
- deserialize(ByteBuffer) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserialize(ByteBuffer) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserialize(ByteBuffer) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserialize(ByteBuffer, byte[]) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserialize(ByteBuffer, int) - Method in class com.linkedin.venice.controller.kafka.protocol.serializer.AdminOperationSerializer
- deserialize(ByteBuffer, InputStream, BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserialize(ByteBuffer, ByteBuffer, BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserialize(ByteBuffer, BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserialize(CompletableFuture<Map<K, V>>, Iterable<E>, List<K>, BiConsumer<Map<K, V>, E>, Reporter, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.deserialization.BatchDeserializer
- deserialize(CompletableFuture<Map<K, V>>, Iterable<E>, List<K>, BiConsumer<Map<K, V>, E>, Reporter, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.deserialization.BlackHoleDeserializer
- deserialize(CompletableFuture<Map<K, V>>, Iterable<E>, List<K>, BiConsumer<Map<K, V>, E>, Reporter, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.deserialization.BlockingDeserializer
- deserialize(BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserialize(BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserialize(BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserialize(T, byte[]) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserialize(T, InputStream, BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserialize(T, ByteBuffer, BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserialize(T, BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserialize(V, byte[]) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserialize(V, InputStream, BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserialize(V, ByteBuffer, BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserialize(V, BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserializeComputeRequest(BinaryDecoder, ComputeRequest) - Static method in class com.linkedin.venice.compute.ComputeUtils
- deserializedSchemaIds - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- deserializeIngestionActionRequest(IngestionAction, byte[]) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- deserializeIngestionActionResponse(IngestionAction, byte[]) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- deserializeObjects(byte[]) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserializeObjects(byte[]) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserializeObjects(byte[]) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserializeObjects(BinaryDecoder) - Method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- deserializeObjects(BinaryDecoder) - Method in class com.linkedin.venice.serializer.AvroGenericDeserializer
- deserializeObjects(BinaryDecoder) - Method in interface com.linkedin.venice.serializer.RecordDeserializer
- deserializeRmdBytes(int, int, ByteBuffer) - Method in class com.linkedin.davinci.replication.merge.RmdSerDe
-
Given a value schema ID and RMD bytes , find the RMD schema that corresponds to the given value schema ID and use that RMD schema to deserialize RMD bytes in a RMD record.
- deserializeStoreVersionState(String, byte[]) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- deserializeValueSchemaIdPrependedRmdBytes(byte[], RmdWithValueSchemaId) - Method in class com.linkedin.davinci.replication.merge.RmdSerDe
-
This method takes in the RMD bytes with prepended value schema ID and a
RmdWithValueSchemaId
container object. - DEST_FABRIC - Enum constant in enum class com.linkedin.venice.Arg
- DEST_FABRIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DEST_ZK_SSL_CONFIG_FILE - Enum constant in enum class com.linkedin.venice.Arg
- DEST_ZOOKEEPER_URL - Enum constant in enum class com.linkedin.venice.Arg
- destClusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
- destClusterName - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
- destinationIdentifier() - Method in interface com.linkedin.davinci.ingestion.consumption.ConsumedDataReceiver
-
N.B.: Used for defensive coding.
- destinationIdentifier() - Method in class com.linkedin.davinci.kafka.consumer.StorePartitionDataReceiver
- destroy() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
- destroyIsolatedIngestionProcess(Process) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- destroyIsolatedIngestionProcessByPid(long) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
-
Kill isolated ingestion process by provided PID.
- destroyLingeringIsolatedIngestionProcess(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
-
This method takes two steps to kill any lingering forked ingestion process previously created by the same user.
- detail - Variable in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
-
Error detail
- detectAndHandleDuplicateKeys(byte[], Iterator<byte[]>, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.DuplicateKeyPrinter
- determineResponseTopic(String, Version, RequestTopicForPushRequest) - Method in class com.linkedin.venice.controller.server.CreateVersion
- determineStoreVersionRole(int, int) - Static method in class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext
- determineWorkloadType(boolean, boolean) - Static method in class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext
- DETERMINISTIC_GUID_GENERATOR_IMPLEMENTATION - Static variable in class com.linkedin.venice.guid.GuidUtils
- DeterministicGuidGenerator - Class in com.linkedin.venice.guid
- DeterministicGuidGenerator(long, long) - Constructor for class com.linkedin.venice.guid.DeterministicGuidGenerator
- DeterministicMapOrderDatumWriter - Interface in org.apache.avro.generic
-
This interface provides method to write map entries in a deterministic order.
- DeterministicMapOrderGenericDatumWriter<T> - Class in org.apache.avro.generic
-
An Avro generic datum writer that sorts the map entries by keys before serializing the map.
- DeterministicMapOrderGenericDatumWriter(GenericData) - Constructor for class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
- DeterministicMapOrderGenericDatumWriter(Schema) - Constructor for class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
- DeterministicMapOrderGenericDatumWriter(Schema, GenericData) - Constructor for class org.apache.avro.generic.DeterministicMapOrderGenericDatumWriter
- DeterministicMapOrderSpecificDatumWriter<T> - Class in org.apache.avro.specific
-
An Avro specific datum writer that sorts the map entries by keys before serializing the map.
- DeterministicMapOrderSpecificDatumWriter() - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
- DeterministicMapOrderSpecificDatumWriter(Class<T>) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
- DeterministicMapOrderSpecificDatumWriter(Schema) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
- DeterministicMapOrderSpecificDatumWriter(Schema, SpecificData) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
- DeterministicMapOrderSpecificDatumWriter(SpecificData) - Constructor for class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
- DICTIONARY - Enum constant in enum class com.linkedin.venice.meta.QueryAction
- DICTIONARY_NOT_DOWNLOADED - Enum constant in enum class com.linkedin.venice.router.stats.StaleVersionReason
- DictionaryFetchRequest - Class in com.linkedin.venice.listener.request
-
DictionaryFetchRequest
encapsulates a GET request to storage/storename/version on the storage node to fetch the compression dictionary for that version. - DictionaryRetrievalService - Class in com.linkedin.venice.router.api
-
DictionaryRetrievalService runs in a producer-consumer pattern.
- DictionaryRetrievalService(OnlineInstanceFinder, VeniceRouterConfig, Optional<SSLFactory>, ReadOnlyStoreRepository, StorageNodeClient, CompressorFactory) - Constructor for class com.linkedin.venice.router.api.DictionaryRetrievalService
- DictionaryUtils - Class in com.linkedin.venice.utils
- DictionaryUtils() - Constructor for class com.linkedin.venice.utils.DictionaryUtils
- diffPubSubPositions(PubSubPosition, PubSubPosition) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
-
Computes the difference in numeric offsets between two
PubSubPosition
instances. - DiffValidationUtils - Class in com.linkedin.venice.utils.consistency
- DirectionalSchemaCompatibilityType - Enum Class in com.linkedin.venice.schema.avro
- directMemoryCapacity - Variable in class com.linkedin.venice.stats.VeniceJVMStats
-
An estimate of the total capacity of the buffers in this pool.
- directMemoryPoolCount - Variable in class com.linkedin.venice.stats.VeniceJVMStats
-
An estimate of the number of buffers in the pool.
- directMemoryUsage - Variable in class com.linkedin.venice.stats.VeniceJVMStats
-
Returns an estimate of the memory that the Java virtual machine is using for this buffer pool.
- directoryContainsFolder(String, String) - Static method in class com.linkedin.venice.utils.TestUtils
- directoryExists(String) - Static method in class com.linkedin.venice.utils.Utils
- DISABLE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - Enum constant in enum class com.linkedin.venice.Command
- DISABLE_DAVINCI_PUSH_STATUS_STORE - Enum constant in enum class com.linkedin.venice.Arg
- DISABLE_DAVINCI_PUSH_STATUS_STORE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DISABLE_LOG - Enum constant in enum class com.linkedin.venice.Arg
- DISABLE_MAX_CAPACITY_PROTECTION - Enum constant in enum class com.linkedin.venice.Command
- DISABLE_META_STORE - Enum constant in enum class com.linkedin.venice.Arg
- DISABLE_META_STORE - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DISABLE_QUTOA_REBALANCE - Enum constant in enum class com.linkedin.venice.Command
- DISABLE_STORE - Enum constant in enum class com.linkedin.venice.Command
- DISABLE_STORE_READ - Enum constant in enum class com.linkedin.venice.Command
- DISABLE_STORE_READ - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DISABLE_STORE_VIEW - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- DISABLE_STORE_WRITE - Enum constant in enum class com.linkedin.venice.Command
- DISABLE_STORE_WRITE - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- DISABLE_THROTTLING - Enum constant in enum class com.linkedin.venice.Command
- disableAndDeleteStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- DISABLED - Static variable in class com.linkedin.davinci.validation.DataIntegrityValidator
- disableDavinciPushStatusStore - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
An UpdateStore command option to disable the companion davinci push status store
- disableDavinciPushStatusStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- DisabledPartitionEnablerService - Class in com.linkedin.venice.controller
- DisabledPartitionEnablerService(VeniceHelixAdmin, VeniceControllerMultiClusterConfig) - Constructor for class com.linkedin.venice.controller.DisabledPartitionEnablerService
- DisabledPartitionEnablerService(VeniceHelixAdmin, VeniceControllerMultiClusterConfig, Time) - Constructor for class com.linkedin.venice.controller.DisabledPartitionEnablerService
- DisabledPartitionStats - Class in com.linkedin.venice.controller.stats
- DisabledPartitionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.DisabledPartitionStats
- disableLog() - Static method in class com.linkedin.venice.LogConfigurator
- disableMetaStore - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
An UpdateStore command option to disable the companion meta system store
- disableMetaStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- disableMetricsEmission() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- disableParentTopicTruncationUponCompletion() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- disableReplica(String, int) - Method in interface com.linkedin.venice.pushmonitor.DisableReplicaCallback
- DisableReplicaCallback - Interface in com.linkedin.venice.pushmonitor
-
The callback method to disable leader replicas whenever they are in ERROR state so that helix can elect a new leader.
- disableRetryOnTimeout() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- disableRetryOnTimeout(BooleanSupplier) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
- DisableStoreRead - Class in com.linkedin.venice.controller.kafka.protocol.admin
- DisableStoreRead() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
-
Default constructor.
- DisableStoreRead(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
-
All-args constructor.
- DISALLOWED_RETRY_COUNT - Enum constant in enum class com.linkedin.venice.router.stats.RouterMetricEntity
-
Count of disallowed retry requests
- disconnect() - Method in class com.linkedin.venice.helix.SafeHelixManager
- disconnect() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- disconnect(ChannelPromise) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- DISCONNECTED - Enum constant in enum class com.linkedin.venice.meta.InstanceStatus
- discoverAndConstructControllerClient(String, String, int, D2Client) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
- discoverAndConstructControllerClient(String, String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
- discoverAndConstructControllerClient(String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
- discoverAndConstructControllerClient(String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.ControllerClientFactory
- discoverBlobPeers(String, int, int) - Method in interface com.linkedin.venice.blobtransfer.BlobFinder
-
This method will look through the partitions for the store and version provided until it finds the partition requested, it will then return the URL of the instances that are ready to serve in the partition.
- discoverBlobPeers(String, int, int) - Method in class com.linkedin.venice.blobtransfer.DaVinciBlobFinder
- discoverBlobPeers(String, int, int) - Method in class com.linkedin.venice.blobtransfer.ServerBlobFinder
- discoverCluster(D2Client, String, String) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
- discoverCluster(D2Client, String, String, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
- discoverCluster(Admin, VeniceControllerRequestHandler) - Static method in class com.linkedin.venice.controller.server.ClusterDiscovery
-
No ACL check; any user is allowed to discover cluster
- discoverCluster(DiscoverClusterGrpcRequest) - Method in class com.linkedin.venice.controller.server.VeniceControllerRequestHandler
- discoverCluster(String) - Method in interface com.linkedin.venice.controller.Admin
-
Find the cluster which the given store belongs to.
- discoverCluster(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- discoverCluster(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- discoverCluster(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- discoverCluster(String) - Method in class com.linkedin.venice.controllerapi.D2ControllerClient
- discoverCluster(String, String, String, int) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
-
Deprecated.
- discoverCluster(String, String, String, int, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClient
- discoverCluster(String, String, Optional<SSLFactory>, int) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
- discoverClusterForStore(DiscoverClusterGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceBlockingStub
-
ClusterDiscovery
- discoverClusterForStore(DiscoverClusterGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceFutureStub
-
ClusterDiscovery
- discoverClusterForStore(DiscoverClusterGrpcRequest, StreamObserver<DiscoverClusterGrpcResponse>) - Method in class com.linkedin.venice.controller.server.VeniceControllerGrpcServiceImpl
- discoverClusterForStore(DiscoverClusterGrpcRequest, StreamObserver<DiscoverClusterGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.AsyncService
-
ClusterDiscovery
- discoverClusterForStore(DiscoverClusterGrpcRequest, StreamObserver<DiscoverClusterGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceStub
-
ClusterDiscovery
- DiscoverClusterGrpcRequest - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- DiscoverClusterGrpcRequest.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- DiscoverClusterGrpcRequestOrBuilder - Interface in com.linkedin.venice.protocols.controller
- DiscoverClusterGrpcResponse - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- DiscoverClusterGrpcResponse.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- DiscoverClusterGrpcResponseOrBuilder - Interface in com.linkedin.venice.protocols.controller
- discoverLeaderController() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- discoverLeaderController() - Method in class com.linkedin.venice.controllerapi.D2ControllerClient
-
Discover leader controller from a list of D2 Clients.
- discoverService() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- DISCOVERY_ERROR - Enum constant in enum class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
- DISK - Enum constant in enum class com.linkedin.davinci.client.StorageClass
-
The mode has the following implications: 1.
- DiskHealthCheckService - Class in com.linkedin.davinci.storage
-
DiskHealthCheckService will wake up every 10 seconds by default and run a health check in the disk by writing 64KB random data, read them back and verify the content; if there is any error within the process, an in-memory state variable "diskHealthy" will be updated to false; otherwise, "diskHealthy" will be kept as true.
- DiskHealthCheckService(boolean, long, long, String, long) - Constructor for class com.linkedin.davinci.storage.DiskHealthCheckService
- DiskHealthStats - Class in com.linkedin.venice.stats
-
DiskHealthStats
measures the disk health conditions based on the periodic tests ran by theDiskHealthCheckService
. - DiskHealthStats(MetricsRepository, DiskHealthCheckService, String) - Constructor for class com.linkedin.venice.stats.DiskHealthStats
- DiskLimitExhaustedException - Exception in com.linkedin.venice.exceptions
- DiskLimitExhaustedException(String) - Constructor for exception com.linkedin.venice.exceptions.DiskLimitExhaustedException
- DiskLimitExhaustedException(String, int, String) - Constructor for exception com.linkedin.venice.exceptions.DiskLimitExhaustedException
- diskUsage - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- DiskUsage - Class in com.linkedin.venice.utils
-
We define a threshold where we consider the disk to be full.
- DiskUsage(String, double) - Constructor for class com.linkedin.venice.utils.DiskUsage
- dispatch(Scatter<Instance, VenicePath, RouterKey>, ScatterGatherRequest<Instance, RouterKey>, VenicePath, BasicHttpRequest, AsyncPromise<Instance>, AsyncPromise<List<FullHttpResponse>>, AsyncPromise<HttpResponseStatus>, AsyncFuture<Void>, Executor) - Method in class com.linkedin.venice.router.api.VeniceDispatcher
- dispatch(Scatter<H, P, K>, ScatterGatherRequest<H, K>, P, BASIC_HTTP_REQUEST, AsyncPromise<H>, AsyncPromise<List<HTTP_RESPONSE>>, AsyncPromise<HTTP_RESPONSE_STATUS>, AsyncFuture<Void>, Executor) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- dispatch(Scatter<H, P, K>, ScatterGatherRequest<H, K>, P, BHS, AsyncPromise<H>, AsyncPromise<List<HR>>, AsyncPromise<HRS>, AsyncFuture<Void>, Executor) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- dispatch(Scatter<H, P, K>, ScatterGatherRequest<H, K>, P, HTTP_REQUEST, AsyncPromise<H>, AsyncPromise<List<HTTP_RESPONSE>>, AsyncPromise<HTTP_RESPONSE_STATUS>, AsyncFuture<Void>, Executor) - Method in interface com.linkedin.alpini.router.api.PartitionDispatchHandler
-
Performs the work.
- dispatcherNettyVersion() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- dispatchHandler(PartitionDispatchHandler<H, P, K, DISPATCH_REQUEST, DISPATCH_RESPONSE, DISPATCH_RESPONSE_STATUS>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
- DispatchingAvroGenericStoreClient<K,
V> - Class in com.linkedin.venice.fastclient -
This class is in charge of routing and serialization/de-serialization.
- DispatchingAvroGenericStoreClient(StoreMetadata, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- DispatchingAvroGenericStoreClient(StoreMetadata, ClientConfig, TransportClient) - Constructor for class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- DispatchingAvroSpecificStoreClient<K,
V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient - DispatchingAvroSpecificStoreClient(StoreMetadata, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DispatchingAvroSpecificStoreClient
- DispatchingVsonStoreClient<K,
V> - Class in com.linkedin.venice.fastclient -
Deprecated.
- DispatchingVsonStoreClient(StoreMetadata, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DispatchingVsonStoreClient
-
Deprecated.
- dispatchMinimumMillis(long) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
- display() - Method in class com.linkedin.venice.ControlMessageDumper
-
Display control messages from each producer
- displayTaskResult(DataRecoveryTask) - Method in class com.linkedin.venice.datarecovery.DataRecoveryEstimator
- displayTaskResult(DataRecoveryTask) - Method in class com.linkedin.venice.datarecovery.DataRecoveryExecutor
- displayTaskResult(DataRecoveryTask) - Method in class com.linkedin.venice.datarecovery.DataRecoveryMonitor
- dispose(O) - Method in class com.linkedin.venice.utils.pools.LandFillObjectPool
- dispose(O) - Method in interface com.linkedin.venice.utils.pools.ObjectPool
-
Return an object to the pool, indicating that it will no longer be used and can be recycled.
- DIV_PRODUCER_STATE_MAX_AGE_MS - Static variable in class com.linkedin.venice.ConfigKeys
-
The maximum age (in milliseconds) of producer state retained by Data Ingestion Validation.
- divErrorMetricCallback - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- DIVStats - Class in com.linkedin.davinci.stats
-
This class contains stats for DIV.
- DIVStats() - Constructor for class com.linkedin.davinci.stats.DIVStats
- DIVStatsReporter - Class in com.linkedin.davinci.stats
-
This class is the reporting class for stats class
DIVStats
. - DIVStatsReporter(MetricsRepository, String, String) - Constructor for class com.linkedin.davinci.stats.DIVStatsReporter
- DIVStatsReporter.DIVStatsGauge - Class in com.linkedin.davinci.stats
- DnsLookupStats - Class in com.linkedin.venice.stats
- DnsLookupStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.stats.DnsLookupStats
- DOES_NOT_EXISTS - Static variable in exception com.linkedin.venice.exceptions.VeniceNoStoreException
- doesResourcesExistInIdealState(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- doesResourcesExistInIdealState(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
-
Whether the resources names exist in ideal state or not.
- doesResultReuseInput() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
- doesSslRequireClientCerts() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- doesSslRequireClientCerts() - Method in class com.linkedin.venice.security.SSLConfig
- DONE - Enum constant in enum class com.linkedin.alpini.base.concurrency.AsyncFuture.Status
- doRecordsDiverge(String, String, List<Long>, List<Long>, List<Long>, List<Long>) - Static method in class com.linkedin.venice.utils.consistency.DiffValidationUtils
-
This method determines that if given the values for two equal keys in a snapshot of venice data, have the records diverged.
- doStart() - Method in class com.linkedin.venice.d2.D2ServerManager
- DOT - Static variable in class com.linkedin.venice.samza.VeniceSystemFactory
- DOT_PRODUCT - Enum constant in enum class com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
- DOT_PRODUCT_RESULT_SCHEMA - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- DOT_PRODUCT_SPEC - Static variable in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- dotProduct(String, List<Float>, String) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- dotProduct(String, List<Float>, String) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
-
Setup dot-product operation.
- dotProduct(List<Float>, List<Float>) - Static method in class com.linkedin.venice.compute.ComputeUtils
- DotProduct - Class in com.linkedin.venice.compute.protocol.request
- DotProduct() - Constructor for class com.linkedin.venice.compute.protocol.request.DotProduct
-
Default constructor.
- DotProduct(CharSequence, List<Float>, CharSequence) - Constructor for class com.linkedin.venice.compute.protocol.request.DotProduct
-
All-args constructor.
- DotProductOperator - Class in com.linkedin.venice.compute
- DotProductOperator() - Constructor for class com.linkedin.venice.compute.DotProductOperator
- dotProductParam - Variable in class com.linkedin.venice.compute.protocol.request.DotProduct
-
The passed feature vector, which will be used to execute dot-product calculation against the field in the original value record
- DoubleAndBooleanConsumer - Interface in com.linkedin.venice.utils
- DoubleAnyOfPredicate - Class in com.linkedin.venice.client.store.predicate
- DoubleEqualsPredicate - Class in com.linkedin.venice.client.store.predicate
- DoubleGreaterOrEqualsPredicate - Class in com.linkedin.venice.client.store.predicate
- DoubleGreaterThanPredicate - Class in com.linkedin.venice.client.store.predicate
- DoubleLowerOrEqualsPredicate - Class in com.linkedin.venice.client.store.predicate
- DoubleLowerThanPredicate - Class in com.linkedin.venice.client.store.predicate
- DoublePredicate - Interface in com.linkedin.venice.client.store.predicate
- DoublyLinkedList<E extends DoublyLinkedList.Entry<E>> - Class in com.linkedin.alpini.base.misc
-
Linked list implementation of the List interface.
- DoublyLinkedList() - Constructor for class com.linkedin.alpini.base.misc.DoublyLinkedList
-
Constructs an empty list.
- DoublyLinkedList(Collection<? extends E>) - Constructor for class com.linkedin.alpini.base.misc.DoublyLinkedList
-
Constructs a list containing the elements of the specified collection, in the order they are returned by the collection's iterator.
- DoublyLinkedList.Entry<E extends DoublyLinkedList.Entry<E>> - Class in com.linkedin.alpini.base.misc
-
In order to maintain a doubly-linked list, each element needs to establish links to its adjacent elements.
- doUpdateSupersetSchemaID - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
-
Whether this superset schema ID should be updated to be the value schema ID for this store.
- drainBufferedRecordsFromTopicPartition(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
-
This method will wait for all the messages to be processed (persisted to disk) that are already queued up to drainer till now.
- drainBufferedRecordsFromTopicPartition(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
- drainBufferedRecordsFromTopicPartition(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
-
This function is used to drain all the records for the specified topic + partition.
- drainTo(Collection<? super T>) - Method in class com.linkedin.venice.utils.collections.MemoryBoundBlockingQueue
- drainTo(Collection<? super T>, int) - Method in class com.linkedin.venice.utils.collections.MemoryBoundBlockingQueue
- drop() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Drop the whole store
- drop() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Drop when it is not required anymore.
- drop() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- drop() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- drop() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- drop() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- drop() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- drop() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
- drop() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- drop() - Method in interface com.linkedin.davinci.store.StorageEngine
-
Drop the whole store
- DROP_PARTITION - Enum constant in enum class com.linkedin.davinci.kafka.consumer.ConsumerActionType
- dropPartition(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Removes and returns a partition from the current store
- dropPartition(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- dropPartition(int) - Method in interface com.linkedin.davinci.store.StorageEngine
-
Removes and returns a partition from the current store
- dropPartition(int, boolean) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Removes and returns a partition from the current store
- dropPartition(int, boolean) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- dropPartition(int, boolean) - Method in interface com.linkedin.davinci.store.StorageEngine
-
Removes and returns a partition from the current store
- DROPPED - Enum constant in enum class com.linkedin.venice.helix.HelixState
- DROPPED - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
Deprecated.
- DROPPED_STATE - Static variable in enum class com.linkedin.venice.helix.HelixState
- dropResource(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Drop a resource from a cluster.
- dropResource(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- dropStorageInstance(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Drop a storage node instance from the given cluster.
- dropStorageInstance(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- dropStoragePartitionGracefully(VeniceStoreVersionConfig, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
-
Drops the corresponding Venice Partition gracefully.
- dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int) - Method in interface com.linkedin.davinci.ingestion.IngestionBackend
-
This method stops to subscribe the specified topic partition and delete partition data from storage and it will always drop empty storage engine.
- dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int, boolean) - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
- dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int, boolean) - Method in interface com.linkedin.davinci.ingestion.IngestionBackend
-
This method stops to subscribe the specified topic partition and delete partition data from storage.
- dropStoragePartitionGracefully(VeniceStoreVersionConfig, int, int, boolean) - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
- dropStoragePartitionGracefully(PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Drops a storage partition gracefully.
- dropStorePartition(VeniceStoreVersionConfig, int) - Method in class com.linkedin.davinci.storage.StorageService
-
Drops the partition of the specified store version in the storage service.
- dropStorePartition(VeniceStoreVersionConfig, int, boolean) - Method in class com.linkedin.davinci.storage.StorageService
-
Drops the partition of the specified store version in the storage service.
- DUAL - Enum constant in enum class com.linkedin.davinci.config.VeniceServerConfig.IncrementalPushStatusWriteMode
-
Write incremental push status to both Zookeeper and push status system store
- DUAL_POOL_STRATEGY - Enum constant in enum class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelFactory.LeaderFollowerThreadPoolStrategy
- DualReadAvroGenericStoreClient<K,
V> - Class in com.linkedin.venice.fastclient -
The following class has capability to send dual read requests via Fast-client and Thin-client.
- DualReadAvroGenericStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DualReadAvroGenericStoreClient
- DualReadAvroGenericStoreClient(InternalAvroStoreClient<K, V>, ClientConfig, AvroGenericStoreClient<K, V>) - Constructor for class com.linkedin.venice.fastclient.DualReadAvroGenericStoreClient
- DualReadAvroSpecificStoreClient<K,
V extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.fastclient - DualReadAvroSpecificStoreClient(InternalAvroStoreClient<K, V>, ClientConfig) - Constructor for class com.linkedin.venice.fastclient.DualReadAvroSpecificStoreClient
- DuckDBDaVinciRecordTransformer - Class in com.linkedin.venice.duckdb
- DuckDBDaVinciRecordTransformer(int, Schema, Schema, Schema, DaVinciRecordTransformerConfig, String, String, Set<String>) - Constructor for class com.linkedin.venice.duckdb.DuckDBDaVinciRecordTransformer
- DUMP_ADMIN_MESSAGES - Enum constant in enum class com.linkedin.venice.Command
- DUMP_CONTROL_MESSAGES - Enum constant in enum class com.linkedin.venice.Command
- DUMP_HOST_HEARTBEAT - Enum constant in enum class com.linkedin.venice.Command
- DUMP_INGESTION_STATE - Enum constant in enum class com.linkedin.venice.Command
- DUMP_INGESTION_STATE - Enum constant in enum class com.linkedin.venice.meta.ServerAdminAction
- DUMP_KAFKA_TOPIC - Enum constant in enum class com.linkedin.venice.Command
- DUMP_SERVER_CONFIGS - Enum constant in enum class com.linkedin.venice.meta.ServerAdminAction
- DUMP_TOPIC_PARTITION_INGESTION_CONTEXT - Enum constant in enum class com.linkedin.venice.Command
- dumpAdminMessages(PubSubConsumerAdapter, String, long, int) - Static method in class com.linkedin.venice.DumpAdminMessages
- DumpAdminMessages - Class in com.linkedin.venice
-
The design consideration to consume in admin tool directly instead of letting controller to consume the required admin message and return them back to admin tool: 1.
- DumpAdminMessages() - Constructor for class com.linkedin.venice.DumpAdminMessages
- DumpAdminMessages.AdminOperationInfo - Class in com.linkedin.venice
- dumpPartitionConsumptionStates(AdminResponse, ComplementSet<Integer>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Invoked by admin request to dump the requested partition consumption states
- dumpStoreVersionState(AdminResponse) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Invoked by admin request to dump store version state metadata.
- DUP_KEY_WITH_DIFF_VALUE - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- DUP_KEY_WITH_DISTINCT_VALUE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- DUP_KEY_WITH_IDENTICAL_VALUE_GROUP_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
- duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
- duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpResponse
- duplicate() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
-
Construct a full copy of the request.
- duplicate() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPart
- duplicate() - Method in interface com.linkedin.alpini.netty4.misc.FullHttpMultiPartRequest
- DUPLICATE_VALUE_SCHEMA_CODE - Static variable in class com.linkedin.venice.schema.SchemaData
- DuplicateDataException - Exception in com.linkedin.venice.exceptions.validation
-
This is a benign
DataValidationException
. - DuplicateDataException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.DuplicateDataException
- DuplicateDataException(String, boolean) - Constructor for exception com.linkedin.venice.exceptions.validation.DuplicateDataException
- duplicateKeyWithDistinctValueCounter - Variable in class com.linkedin.venice.spark.datawriter.task.DataWriterAccumulators
- duplicateKeyWithIdenticalValueCounter - Variable in class com.linkedin.venice.spark.datawriter.task.DataWriterAccumulators
- DuplicateTopicException - Exception in com.linkedin.venice.ingestion.control
-
The source and destination topic for topic switching are the same topic
- DuplicateTopicException(String) - Constructor for exception com.linkedin.venice.ingestion.control.DuplicateTopicException
- DuplicatingPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
-
A
PollStrategy
implementation which can introduce duplicates. - DuplicatingPollStrategy(AbstractPollStrategy, Set<PubSubTopicPartitionOffset>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.DuplicatingPollStrategy
- DurableWrite - Class in com.linkedin.venice.producer
-
This class is used as the return type of the
CompletableFuture
that is returned by the Venice producer. - DurableWrite() - Constructor for class com.linkedin.venice.producer.DurableWrite
- DVC_INGESTION_ERROR_DISK_FULL - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- DVC_INGESTION_ERROR_DISK_FULL - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
DaVinci client fails ingestion due to disk reaching the threshold in the host
- DVC_INGESTION_ERROR_MEMORY_LIMIT_REACHED - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- DVC_INGESTION_ERROR_MEMORY_LIMIT_REACHED - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
DaVinci client fails ingestion due to reaching the configured memory limit in the host
- DVC_INGESTION_ERROR_OTHER - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- DVC_INGESTION_ERROR_OTHER - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
Other uncategorized DaVinci Client errors
- DVC_INGESTION_ERROR_TOO_MANY_DEAD_INSTANCES - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- DVC_INGESTION_ERROR_TOO_MANY_DEAD_INSTANCES - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
There are too many dead DaVinci instances leading to failed push job
- DynamicAccessController - Interface in com.linkedin.venice.acl
-
A DynamicAccessController is an AccessController with a mutable resource list.
E
- EARLIEST - Static variable in class com.linkedin.venice.pubsub.api.PubSubSymbolicPosition
-
Singleton instance representing the earliest retrievable position in a partition.
- EARLIEST_POSITION_RESERVED_TYPE_ID - Static variable in class com.linkedin.venice.pubsub.PubSubPositionTypeRegistry
-
Reserved type IDs for internal standard
PubSubPosition
implementations. - EarliestPositionFactory - Class in com.linkedin.venice.pubsub
-
A
PubSubPositionFactory
for the symbolicPubSubSymbolicPosition.EARLIEST
marker. - EarliestPositionFactory(int) - Constructor for class com.linkedin.venice.pubsub.EarliestPositionFactory
- EARLY_THROTTLE_ENABLED - Static variable in class com.linkedin.venice.router.AdminOperationsHandler
- element() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
-
Returns the first element in this list.
- element() - Method in class com.linkedin.venice.utils.collections.MemoryBoundBlockingQueue
- ElementTimestampAndIdx - Class in com.linkedin.venice.schema.rmd.v1
-
A POJO containing an index and a timestamp for a collection element.
- EMERGENCY_SOURCE_REGION - Static variable in class com.linkedin.venice.ConfigKeys
-
The highest priority source fabric selection config, specified in parent controller.
- emitChunkedRecordCountMetrics(VeniceResponseStatusCategory) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
-
This won't be emitted by DVRT CDC, since it doesn't have context into chunked records.
- emitCurrentConsumingVersionMetrics(int, int) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
- emitHealthyRequestMetrics(double, int) - Method in class com.linkedin.venice.client.stats.BasicClientStats
- emitHealthyRequestMetrics(double, Object) - Method in class com.linkedin.venice.client.stats.BasicClientStats
- emitHealthyRequestMetricsForDavinciClient(double) - Method in class com.linkedin.venice.client.stats.BasicClientStats
- emitHeartBeatDelayMetrics(long) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
-
This won't be emitted by DVRT CDC, since it doesn't have context into heartbeat delay.
- emitMetrics - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- emitOpenTelemetryMetrics() - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- emitOtelMetrics() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- emitPollCountMetrics(VeniceResponseStatusCategory) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
- emitRecordsConsumedCountMetrics(int) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
- emitUnhealthyRequestMetrics(double, int) - Method in class com.linkedin.venice.client.stats.BasicClientStats
- emitUnhealthyRequestMetrics(double, Throwable) - Method in class com.linkedin.venice.client.stats.BasicClientStats
- emitUnhealthyRequestMetricsForDavinciClient(double) - Method in class com.linkedin.venice.client.stats.BasicClientStats
- emitVersionSwapCountMetrics(VeniceResponseStatusCategory) - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
- empty() - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
- empty() - Static method in class com.linkedin.venice.utils.VeniceProperties
- EMPTY - Static variable in class com.linkedin.venice.utils.ByteArray
- EMPTY - Static variable in class com.linkedin.venice.utils.LogContext
- EMPTY_BYTE_ARRAY - Static variable in class com.linkedin.venice.writer.VeniceWriter
- EMPTY_BYTE_BUF - Static variable in class com.linkedin.venice.router.streaming.VeniceChunkedResponse
- EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
- EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.venice.streaming.StreamingUtils
- EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.venice.writer.VeniceWriter
- EMPTY_BYTE_BUFFER - Static variable in class com.linkedin.venice.writer.WriterChunkingHelper
- EMPTY_HEADERS - Static variable in interface com.linkedin.alpini.base.misc.Headers
- EMPTY_KEY_LENGTH - Static variable in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
- EMPTY_PUSH - Enum constant in enum class com.linkedin.venice.Command
- EMPTY_PUSH - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- EMPTY_RECORD_COUNTER_NAME - Static variable in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- EMPTY_RECORD_HEADERS - Static variable in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaUtils
- emptyPollSleepMs - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- EmptyPubSubMessageHeaders - Class in com.linkedin.venice.pubsub.api
- emptyPush(Admin) - Method in class com.linkedin.venice.controller.server.CreateVersion
- emptyPush(String, String, long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- emptyRecordCounter - Variable in class com.linkedin.venice.spark.datawriter.task.DataWriterAccumulators
- emptySet() - Static method in class com.linkedin.venice.utils.ComplementSet
- ENABLE_ACTIVE_ACTIVE_REPLICATION_AS_DEFAULT_FOR_HYBRID_STORE - Static variable in class com.linkedin.venice.ConfigKeys
-
Cluster-level config to enable active-active replication for new hybrid stores.
- ENABLE_ACTIVE_ACTIVE_REPLICATION_FOR_CLUSTER - Enum constant in enum class com.linkedin.venice.Command
- ENABLE_BLOB_TRANSFER - Static variable in class com.linkedin.venice.ConfigKeys
-
Store-level config to enable blob transfers (feature flag)
- ENABLE_CHUNKING - Static variable in class com.linkedin.venice.writer.VeniceWriter
- ENABLE_DISABLED_REPLICA - Enum constant in enum class com.linkedin.venice.Arg
- ENABLE_DISABLED_REPLICAS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- ENABLE_GRPC_READ_SERVER - Static variable in class com.linkedin.venice.ConfigKeys
- ENABLE_HYBRID_PUSH_SSL_ALLOWLIST - Static variable in class com.linkedin.venice.ConfigKeys
-
The switcher to enable/disable the allowlist of ssl hybrid pushes including both batch and near-line pushes for that store.
- ENABLE_HYBRID_PUSH_SSL_WHITELIST - Static variable in class com.linkedin.venice.ConfigKeys
-
Deprecated.
- ENABLE_INCREMENTAL_PUSH_FOR_HYBRID_ACTIVE_ACTIVE_USER_STORES - Static variable in class com.linkedin.venice.ConfigKeys
-
We will use this config to determine whether we should enable incremental push for hybrid active-active user stores.
- ENABLE_MAX_CAPACITY_PROTECTION - Enum constant in enum class com.linkedin.venice.Command
- ENABLE_MAX_CAPACITY_PROTECTION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ENABLE_OFFLINE_PUSH_SSL_ALLOWLIST - Static variable in class com.linkedin.venice.ConfigKeys
-
The switcher to enable/disable the allowlist of ssl offline pushes.
- ENABLE_OFFLINE_PUSH_SSL_WHITELIST - Static variable in class com.linkedin.venice.ConfigKeys
-
Deprecated.
- ENABLE_PARTIAL_UPDATE_FOR_HYBRID_ACTIVE_ACTIVE_USER_STORES - Static variable in class com.linkedin.venice.ConfigKeys
-
We will use this config to determine whether we should enable partial update for hybrid active-active user stores.
- ENABLE_PARTIAL_UPDATE_FOR_HYBRID_NON_ACTIVE_ACTIVE_USER_STORES - Static variable in class com.linkedin.venice.ConfigKeys
-
We will use this config to determine whether we should enable partial update for hybrid non-active-active user stores.
- ENABLE_PARTITION_COUNT_ROUND_UP - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether to round up the version-level partition count calculated by storage quota.
- ENABLE_QUOTA_REBALANCED - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ENABLE_QUTOA_REBALANCE - Enum constant in enum class com.linkedin.venice.Command
- ENABLE_READS - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- ENABLE_RMD_CHUNKING - Static variable in class com.linkedin.venice.writer.VeniceWriter
- ENABLE_SEPARATE_REAL_TIME_TOPIC_FOR_STORE_WITH_INCREMENTAL_PUSH - Static variable in class com.linkedin.venice.ConfigKeys
-
We will use this config to determine whether we should enable separate real-time topic for incremental push enabled stores.
- ENABLE_SERVER_ALLOW_LIST - Static variable in class com.linkedin.venice.ConfigKeys
- ENABLE_SSL - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- ENABLE_STORE - Enum constant in enum class com.linkedin.venice.Command
- ENABLE_STORE - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ENABLE_STORE_MIGRATION - Enum constant in enum class com.linkedin.venice.Arg
- ENABLE_STORE_MIGRATION - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
-
Constant for enabling store migration.
- ENABLE_STORE_READ - Enum constant in enum class com.linkedin.venice.Command
- ENABLE_STORE_READ - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- ENABLE_STORE_WRITE - Enum constant in enum class com.linkedin.venice.Command
- ENABLE_STORE_WRITE - Enum constant in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- ENABLE_THROTTLING - Enum constant in enum class com.linkedin.venice.Command
- ENABLE_THROTTLING - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- ENABLE_UNCOMPRESSED_RECORD_SIZE_LIMIT - Static variable in class com.linkedin.venice.writer.VeniceWriter
-
Enable maximum record size before record compression.
- ENABLE_WRITE_COMPUTE - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- ENABLE_WRITES - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- enableActiveActiveReplicationForCluster(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- enabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
- enabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
- enabledIncrementalPushForHybridActiveActiveUserStores() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- enableDisabledPartition(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- enabledSeparateRealTimeTopicForStoreWithIncrementalPush() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- enableInboundHttp2(boolean) - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- enableInboundHttp2(boolean) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
- enableInboundHttp2(boolean) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
- enableMaxCapacityProtection(boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- enableMaxCapacityProtection(boolean) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
- enableMaxCapacityProtection(boolean) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
-
Enable or disable max read capacity protection feature on router.
- enableMaxCapacityProtection(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
-
Enable max capacity protection by updating the cluster level for all routers.
- enableMetricsEmission() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- enablePartition(boolean, String, String, String, List<String>) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Disable or enable a list of partitions on an instance.
- enablePartition(boolean, String, String, String, List<String>) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- enableQuotaRebalanced(boolean, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- enableQuotaRebalanced(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
-
Enable quota rebalanced by updating the cluster level for all routers.
- enableReads - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- enableReads - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- enableReads - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
If a store is disabled from being read, none of versions under this store could serve read requests.
- enableResolveBeforeSSL(EventExecutorGroup, int, long) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Configure for performing DNS resolution of the client address on an alternate thread pool to avoid and limit DNS execution during SSL handshake from blocking the IO Workers.
- enableResolveBeforeSSL(EventExecutorGroup, int, long, int, boolean) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Configure for performing DNS resolution of the client address on an alternate thread pool to avoid and limit DNS execution during SSL handshake from blocking the IO Workers.
- enableRetryRequestAlwaysUseADifferentHost(boolean) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
- enableRetryRequestAlwaysUseADifferentHost(BooleanSupplier) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
- enableSSL - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- enableSslTaskExecutor(ThreadPoolExecutor) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Configure for enabling the SslHandler to offload handshake compute tasks to an alternate executor.
- enableSslTaskExecutor(ThreadPoolExecutor, Consumer<Integer>) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
- enableStackTraceResponseForException(boolean) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper.Builder
- enableStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
-
enable/disable store read/write ability
- EnableStoreRead - Class in com.linkedin.venice.controller.kafka.protocol.admin
- EnableStoreRead() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
-
Default constructor.
- EnableStoreRead(CharSequence, CharSequence) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
-
All-args constructor.
- enableStoreReads(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- enableStoreReadWrites(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- enableStoreWrites(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- enableThrottling(boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- enableThrottling(boolean) - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
- enableThrottling(boolean) - Method in interface com.linkedin.venice.meta.RoutersClusterManager
-
Enable or disable read throttling feature on router.
- enableThrottling(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
-
Enable throttling by updating the cluster level for all routers.
- enableUncompressedRecordSizeLimit - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- enableWriteCompute - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- enableWrites - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- enableWrites - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- enableWrites - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
If a store is disabled from writing, new version can not be created for it.
- encode(VeniceCheckpointMark, OutputStream) - Method in class com.linkedin.venice.beam.consumer.VeniceCheckpointMark.Coder
- encode(PubSubMessage<K, ChangeEvent<V>, VeniceChangeCoordinate>, OutputStream) - Method in class com.linkedin.venice.beam.consumer.PubSubMessageCoder
- encode(ChannelHandlerContext, HttpObject, List<Object>) - Method in class com.linkedin.alpini.netty4.http2.AbstractHttp2StreamFrameCodec
-
Encode from an
HttpObject
to anHttp2StreamFrame
. - encode(CharSequence, Charset) - Static method in enum class com.linkedin.alpini.base.misc.URLCodec
-
Translates a string into
application/x-www-form-urlencoded
format using a specific encoding scheme. - encode(String, Charset) - Static method in enum class com.linkedin.alpini.base.misc.URLCodec
-
Translates a string into
application/x-www-form-urlencoded
format using a specific encoding scheme. - encode(KV<K, ChangeEvent<V>>, OutputStream) - Method in class com.linkedin.venice.beam.consumer.VeniceMessageCoder
- encodeInitialLine(ByteBuf, HttpResponse) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Encoder
- encodeQueryParams(QueryParams) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
- Encoder() - Constructor for class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec.Encoder
- EncodingUtils - Class in com.linkedin.venice.utils
- EncodingUtils() - Constructor for class com.linkedin.venice.utils.EncodingUtils
- end(boolean) - Method in class com.linkedin.venice.kafka.validation.Segment
- END_BATCH_PUSH - Enum constant in enum class com.linkedin.davinci.store.StoragePartitionAdjustmentTrigger
- END_DATE - Enum constant in enum class com.linkedin.venice.Arg
- END_FABRIC_BUILDOUT - Enum constant in enum class com.linkedin.venice.Command
- END_MIGRATION - Enum constant in enum class com.linkedin.venice.Command
- END_MIGRATION - Enum constant in enum class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Step
- END_OF_FINAL_SEGMENT - Enum constant in enum class com.linkedin.venice.kafka.validation.SegmentStatus
-
Received
ControlMessageType.END_OF_SEGMENT
with finalSegment = true. - END_OF_INCREMENTAL_PUSH - Enum constant in enum class com.linkedin.venice.kafka.protocol.enums.ControlMessageType
- END_OF_INCREMENTAL_PUSH_RECEIVED - Enum constant in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
- END_OF_INCREMENTAL_PUSH_RECEIVED - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
An incremental push job/task is completed
- END_OF_INCREMENTAL_PUSH_RECEIVED - Enum constant in enum class com.linkedin.venice.status.PushJobDetailsStatus
- END_OF_INTERMEDIATE_SEGMENT - Enum constant in enum class com.linkedin.venice.kafka.validation.SegmentStatus
-
Received
ControlMessageType.END_OF_SEGMENT
with finalSegment = false. - END_OF_PUSH - Enum constant in enum class com.linkedin.venice.authorization.Method
- END_OF_PUSH - Enum constant in enum class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read.SeekWhence
- END_OF_PUSH - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- END_OF_PUSH - Enum constant in enum class com.linkedin.venice.kafka.protocol.enums.ControlMessageType
- END_OF_PUSH_RECEIVED - Enum constant in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
- END_OF_PUSH_RECEIVED - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
Tasks belonging to a Hybrid Store emits this instead of
ExecutionStatus.COMPLETED
when it consumes a EOP message - END_OF_PUSH_RECEIVED - Enum constant in enum class com.linkedin.venice.status.PushJobDetailsStatus
- END_OF_SEGMENT - Enum constant in enum class com.linkedin.venice.kafka.protocol.enums.ControlMessageType
- endBatchWrite() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
- endBatchWrite() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- endBatchWrite() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- endBatchWrite(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- endBatchWrite(StoragePartitionConfig) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- endBatchWrite(StoragePartitionConfig) - Method in interface com.linkedin.davinci.store.StorageEngine
- endOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- endOffset(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
-
Retrieves the end offset for the specified PubSub topic-partition.
- endOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
- endOffsets(String, int) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
- endOffsets(Collection<PubSubTopicPartition>, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- endOffsets(Collection<PubSubTopicPartition>, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
-
Retrieves the end offsets for a collection of PubSub topic-partitions.
- endOffsets(Collection<PubSubTopicPartition>, Duration) - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
- EndOfIncrementalPush - Class in com.linkedin.venice.kafka.protocol
-
This ControlMessage is sent per partition by each offline incremental push job, once per partition, at the end of a incremental push
- EndOfIncrementalPush() - Constructor for class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
-
Default constructor.
- EndOfIncrementalPush(CharSequence) - Constructor for class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
-
All-args constructor.
- endOfIncrementalPushReceived(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
-
Consumption is completed for an incremental push
- endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
- endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
- endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
- endOfIncrementalPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
- endOfIncrementalPushReceived(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
- endOfPush - Variable in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Whether the EndOfPush control message was consumed in this partition.
- EndOfPush - Class in com.linkedin.venice.kafka.protocol
-
This ControlMessage is sent once per partition, at the end of a bulk load, after all of the data producers come online.
- EndOfPush() - Constructor for class com.linkedin.venice.kafka.protocol.EndOfPush
- endOfPushReceived(long) - Method in class com.linkedin.venice.offsets.OffsetRecord
- endOfPushReceived(String, int, long) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
-
The
ControlMessageType.END_OF_PUSH
control message was consumed. - endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
- endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.LogNotifier
- endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
- endOfPushReceived(String, int, long, String) - Method in class com.linkedin.davinci.notifier.RelayNotifier
- endOfPushReceived(String, int, long, String) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
- endOfPushTimestamp - Variable in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
The messageTimestamp from the producerMetadata of EndOfPush control message.
- EndOfSegment - Class in com.linkedin.venice.kafka.protocol
-
This ControlMessage is sent at least once per partition per producer.
- EndOfSegment() - Constructor for class com.linkedin.venice.kafka.protocol.EndOfSegment
-
Default constructor.
- EndOfSegment(ByteBuffer, List<Long>, Boolean) - Constructor for class com.linkedin.venice.kafka.protocol.EndOfSegment
-
All-args constructor.
- endPosition(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- endPosition(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
- endPositions(Collection<PubSubTopicPartition>, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- endPositions(Collection<PubSubTopicPartition>, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
- endStreamReprocessingSystemProducer(SystemProducer, boolean) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
RouterBasedPushMonitor
will update the status of a SystemProducer with push type STREAM_REPROCESSING: END_OF_PUSH_RECEIVED: isActive -> false; isStreamReprocessingJobSucceeded -> true COMPLETED: isActive -> false; isStreamReprocessingJobSucceeded -> true ERROR: isActive -> false; isStreamReprocessingJobSucceeded -> false For all the other push job status, SystemProducer status will not be updated. - ENFORCE_SECURE_ROUTER - Static variable in class com.linkedin.venice.ConfigKeys
-
Whether to block storage requests on the non-ssl port.
- enforceMemoryLimit(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
-
Whether memory limiter applies or not.
- enforceMemoryLimitInStore(String) - Method in class com.linkedin.davinci.config.VeniceServerConfig
- enforcePartitionQuota(int, long) - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
- enforceQuota(RouterRequest) - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
-
Enforce quota for a given request.
- EngineTaskConfigProvider - Interface in com.linkedin.venice.hadoop.engine
-
An interface to get information about a running job and task on any batch computing engine.
- enlargeByteBufferForIntHeader(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
-
This function is to simulate the deserialization logic in com.linkedin.venice.serialization.avro.OptimizedKafkaValueSerializer to leave some room at the beginning of byte buffer of 'byteBuffer'
- ensureTopicIsDeletedAndBlock(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Delete a topic and block until it is deleted or operation times out.
- ensureTopicIsDeletedAndBlockWithRetry(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Delete a topic with retry and block until it is deleted or operation times out.
- entries() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- entry(K, V) - Static method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
- Entry() - Constructor for class com.linkedin.alpini.base.misc.DoublyLinkedList.Entry
- entrySet() - Method in class com.linkedin.davinci.utils.IndexedHashMap
-
Returns a
Set
view of the mappings contained in this map. - EnumUtils - Class in com.linkedin.venice.utils
- EnumUtils() - Constructor for class com.linkedin.venice.utils.EnumUtils
- ENVIRONMENT_CONFIG_KEY_FOR_REGION_NAME - Static variable in class com.linkedin.venice.VeniceConstants
- equals(Object) - Method in class com.linkedin.alpini.base.misc.Pair
-
Test for equality between this and
obj
. - equals(Object) - Method in class com.linkedin.alpini.netty4.handlers.ShutdownableChannelGroup
- equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpMultiPart
- equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicFullHttpRequest
- equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpMultiPart
- equals(Object) - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
- equals(Object) - Method in class com.linkedin.alpini.router.api.ScatterGatherMode
- equals(Object) - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
- equals(Object) - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- equals(Object) - Method in class com.linkedin.davinci.kafka.consumer.ReplicaHeartbeatInfo
- equals(Object) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionForIngestion
- equals(Object) - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- equals(Object) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
- equals(Object) - Method in class com.linkedin.davinci.store.StoragePartitionConfig
- equals(Object) - Method in class com.linkedin.davinci.utils.ByteArrayKey
- equals(Object) - Method in class com.linkedin.venice.authorization.AceEntry
- equals(Object) - Method in class com.linkedin.venice.authorization.AclBinding
- equals(Object) - Method in class com.linkedin.venice.authorization.Principal
- equals(Object) - Method in class com.linkedin.venice.authorization.Resource
- equals(Object) - Method in class com.linkedin.venice.client.store.ClientConfig
- equals(Object) - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
- equals(Object) - Method in class com.linkedin.venice.compression.GzipCompressor
- equals(Object) - Method in class com.linkedin.venice.compression.NoopCompressor
- equals(Object) - Method in class com.linkedin.venice.compression.ZstdWithDictCompressor
- equals(Object) - Method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
- equals(Object) - Method in class com.linkedin.venice.kafka.validation.Segment
- equals(Object) - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
- equals(Object) - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
- equals(Object) - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- equals(Object) - Method in class com.linkedin.venice.meta.Instance
- equals(Object) - Method in class com.linkedin.venice.meta.Partition
- equals(Object) - Method in class com.linkedin.venice.meta.PartitionAssignment
- equals(Object) - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
- equals(Object) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- equals(Object) - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- equals(Object) - Method in class com.linkedin.venice.meta.ReadOnlyViewStore
- equals(Object) - Method in class com.linkedin.venice.meta.ReadOnlyViewStore.ReadOnlyMaterializedViewVersion
- equals(Object) - Method in class com.linkedin.venice.meta.RoutersClusterConfig
- equals(Object) - Method in class com.linkedin.venice.meta.StoreConfig
- equals(Object) - Method in class com.linkedin.venice.meta.StoreName
- equals(Object) - Method in class com.linkedin.venice.meta.StoreVersionName
- equals(Object) - Method in class com.linkedin.venice.meta.SystemStore
- equals(Object) - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
- equals(Object) - Method in class com.linkedin.venice.meta.VersionImpl
- equals(Object) - Method in class com.linkedin.venice.meta.ZKStore
- equals(Object) - Method in class com.linkedin.venice.offsets.OffsetRecord
- equals(Object) - Method in class com.linkedin.venice.persona.Persona
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- equals(Object) - Method in class com.linkedin.venice.protocols.VeniceClientRequest
- equals(Object) - Method in class com.linkedin.venice.protocols.VeniceServerResponse
- equals(Object) - Method in class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPosition
- equals(Object) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeader
- equals(Object) - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
- equals(Object) - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
- equals(Object) - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
- equals(Object) - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- equals(Object) - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
- equals(Object) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- equals(Object) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
- equals(Object) - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- equals(Object) - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
- equals(Object) - Method in class com.linkedin.venice.router.api.RouterKey
- equals(Object) - Method in class com.linkedin.venice.router.api.VeniceFullHttpResponse
- equals(Object) - Method in class com.linkedin.venice.routerapi.ReplicaState
- equals(Object) - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
- equals(Object) - Method in class com.linkedin.venice.schema.GeneratedSchemaEntry
- equals(Object) - Method in class com.linkedin.venice.schema.GeneratedSchemaID
- equals(Object) - Method in class com.linkedin.venice.schema.rmd.RmdSchemaEntry
- equals(Object) - Method in class com.linkedin.venice.schema.rmd.RmdVersionId
- equals(Object) - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- equals(Object) - Method in class com.linkedin.venice.schema.SchemaEntry
- equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsArrayList
-
Deprecated.
- equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroDatumReader.DeepEqualsHashMap
-
Deprecated.
- equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
-
Deprecated.
- equals(Object) - Method in class com.linkedin.venice.schema.vson.VsonSchema
-
Deprecated.
- equals(Object) - Method in class com.linkedin.venice.serializer.SerializerDeserializerFactory.SchemaPairAndClassContainer
- equals(Object) - Method in class com.linkedin.venice.sql.ColumnDefinition
- equals(Object) - Method in class com.linkedin.venice.sql.TableDefinition
- equals(Object) - Method in class com.linkedin.venice.status.StoreStatusMessage
- equals(Object) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
- equals(Object) - Method in class com.linkedin.venice.utils.ByteArray
- equals(Object) - Method in class com.linkedin.venice.utils.HashCodeComparator
- equals(Object) - Method in class com.linkedin.venice.utils.Pair
-
Deprecated.
- equals(Object) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
- equals(Object) - Method in class com.linkedin.venice.utils.VeniceProperties
- equals(Object) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- EqualsPredicate<T> - Class in com.linkedin.venice.client.store.predicate
- equalTo(double, double) - Static method in interface com.linkedin.venice.client.store.predicate.DoublePredicate
- equalTo(float, float) - Static method in interface com.linkedin.venice.client.store.predicate.FloatPredicate
- equalTo(int) - Static method in interface com.linkedin.venice.client.store.predicate.IntPredicate
- equalTo(long) - Static method in interface com.linkedin.venice.client.store.predicate.LongPredicate
- equalTo(String, Object) - Static method in interface com.linkedin.venice.client.store.predicate.Predicate
- equalTo(O) - Static method in interface com.linkedin.venice.client.store.predicate.Predicate
- error - Variable in class com.linkedin.venice.datarecovery.Command.Result
- error - Variable in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
-
The first error founded during in`gestion
- error(String, int, String, Exception) - Method in class com.linkedin.davinci.helix.StateModelIngestionProgressNotifier
- error(String, int, String, Exception) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionNotifier
- error(String, int, String, Exception) - Method in class com.linkedin.davinci.notifier.LogNotifier
- error(String, int, String, Exception) - Method in class com.linkedin.davinci.notifier.PushStatusNotifier
- error(String, int, String, Exception) - Method in class com.linkedin.davinci.notifier.RelayNotifier
- error(String, int, String, Exception) - Method in interface com.linkedin.davinci.notifier.VeniceNotifier
-
Report an error, during the consumption for a Partitions and store.
- error(String, int, String, Exception) - Method in class com.linkedin.venice.utils.ExceptionCaptorNotifier
- ERROR - Enum constant in enum class com.linkedin.venice.controllerapi.AdminCommandExecutionStatus
- ERROR - Enum constant in enum class com.linkedin.venice.helix.HelixState
- ERROR - Enum constant in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
- ERROR - Enum constant in enum class com.linkedin.venice.meta.VersionStatus
-
Version is not serving read requests, and it's relevant push job has failed
- ERROR - Enum constant in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
-
Job/task met error when processing the data.
- ERROR - Enum constant in enum class com.linkedin.venice.status.protocol.enums.PushJobStatus
- ERROR - Enum constant in enum class com.linkedin.venice.status.PushJobDetailsStatus
- ERROR - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- ERROR_FORBIDDEN - Enum constant in enum class com.linkedin.venice.acl.handler.AccessResult
- ERROR_PARTITION_AUTO_RESET_LIMIT - Static variable in class com.linkedin.venice.ConfigKeys
-
Maximum number of times controller will automatically reset an error partition for the current/serving version to mitigate impact of transient or long running issues during re-balance or restart.
- ERROR_PARTITION_PROCESSING_CYCLE_DELAY - Static variable in class com.linkedin.venice.ConfigKeys
-
The delay between each cycle where we iterate over all applicable resources and their partition to reset error partitions and collect data on the effectiveness of previous resets.
- ERROR_RETRY - Enum constant in enum class com.linkedin.venice.stats.dimensions.RequestRetryType
- ERROR_RETRY_REQUEST - Enum constant in enum class com.linkedin.venice.fastclient.stats.FastClientStats.FastClientTehutiMetricName
- ERROR_STATE - Static variable in enum class com.linkedin.venice.helix.HelixState
- ErrorCatchingHandler - Class in com.linkedin.venice.listener
-
Expects a GetRequestObject which has store name, key, and partition Queries the local store for the associated value writes the value (as a byte[]) back down the stack
- ErrorCatchingHandler() - Constructor for class com.linkedin.venice.listener.ErrorCatchingHandler
- ERRORCODE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
- ERRORMESSAGE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- ERRORMESSAGE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.VeniceServerResponse
- errorPartitionId - Variable in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Used for reporting error when the
StoreIngestionTask.partitionConsumptionStateMap
is empty - ErrorPartitionResetTask - Class in com.linkedin.venice.controller
-
A task that iterates over store version resources and reset error partitions if they meet the following criteria: The store version resource is the current version. The error partition only has exactly one error replica. For L/F model, using EV to check error replicas misses internal error replica states.
- ErrorPartitionResetTask(String, HelixAdminClient, ReadOnlyStoreRepository, HelixExternalViewRepository, PushMonitor, MetricsRepository, int, long) - Constructor for class com.linkedin.venice.controller.ErrorPartitionResetTask
- ErrorPartitionStats - Class in com.linkedin.venice.controller.stats
- ErrorPartitionStats(MetricsRepository, String) - Constructor for class com.linkedin.venice.controller.stats.ErrorPartitionStats
- errorReported - Variable in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Whether error has already been reported
- errorReported() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- errorRequest(ServerHttpRequestStats, double) - Method in class com.linkedin.venice.listener.ServerStatsContext
- errorType - Variable in exception com.linkedin.venice.exceptions.VeniceException
- ErrorType - Enum Class in com.linkedin.venice.exceptions
-
ExceptionType
enum did not have a default deserialization annotation and this makes it non-evolvable till all clients upgrade to newer versions. - ERRORTYPE_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- escapeDelimiters(StringBuilder, CharSequence) - Static method in enum class com.linkedin.alpini.base.misc.HeaderUtils
- escapeFilePathComponent(String) - Static method in class com.linkedin.venice.utils.Utils
-
Method to escape file path component to make it a valid file path string/substring.
- EspressoHttp2FrameCodec - Class in io.netty.handler.codec.http2
-
An extension of the
Http2FrameCodec
which provides a facility to be able to block stream creation from clients without incurring any cost of stream creation on the server side. - EspressoHttp2FrameCodecBuilder - Class in io.netty.handler.codec.http2
- EspressoHttp2FrameCodecUtil - Class in io.netty.handler.codec.http2
-
Utility class to expose package private members.
- EspressoHttp2MultiplexHandler - Class in io.netty.handler.codec.http2
-
Forked from Netty's Http2MultiplexHandler (4.1.42) (https://github.com/netty/netty/blob/4.1/codec-http2/src/main/java/io/netty/handler/codec/http2/Http2MultiplexHandler.java) In HTTP/1.1, the requests from the client are distributed across 48 workers threads of router.
- EspressoHttp2MultiplexHandler(ChannelHandler) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
-
Creates a new instance
- EspressoHttp2MultiplexHandler(ChannelHandler, boolean, boolean) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
- EspressoHttp2MultiplexHandler(ChannelHandler, ChannelHandler) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
-
Creates a new instance
- EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel - Class in io.netty.handler.codec.http2
- EspressoHttp2StreamChannelBootstrap - Class in io.netty.handler.codec.http2
-
Forked from Netty 4
Http2StreamChannelBootstrap
to allow usingEspressoHttp2MultiplexHandler
in the pipeline. - EspressoHttp2StreamChannelBootstrap(Channel) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
- EspressoHttp2StreamChannelBootstrap(Channel, boolean) - Constructor for class io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap
- ESTIMATE_DATA_RECOVERY_TIME - Enum constant in enum class com.linkedin.venice.Command
- EstimateDataRecoveryTimeCommand - Class in com.linkedin.venice.datarecovery
- EstimateDataRecoveryTimeCommand() - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
- EstimateDataRecoveryTimeCommand(EstimateDataRecoveryTimeCommand.Params) - Constructor for class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
- EstimateDataRecoveryTimeCommand.Params - Class in com.linkedin.venice.datarecovery
- EstimateDataRecoveryTimeCommand.Params.Builder - Class in com.linkedin.venice.datarecovery
- EstimateDataRecoveryTimeCommand.Result - Class in com.linkedin.venice.datarecovery
- estimateRecoveryTime(DataRecoveryClient.DataRecoveryParams, EstimateDataRecoveryTimeCommand.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
- ETERNAL_TOPIC_RETENTION_ENABLED - Static variable in class com.linkedin.venice.views.ViewUtils
- ETERNAL_TOPIC_RETENTION_POLICY_MS - Static variable in class com.linkedin.venice.pubsub.PubSubConstants
- ETL_KEY_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
- ETL_UNION_VALUE_WITH_NULL_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
- ETL_UNION_VALUE_WITHOUT_NULL_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
- ETL_VALUE_SCHEMA - Static variable in class com.linkedin.venice.utils.TestWriteUtils
- ETL_VALUE_SCHEMA_TRANSFORMATION - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- etlConfig - Variable in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Properties related to ETL Store behavior.
- ETLED_PROXY_USER_ACCOUNT - Enum constant in enum class com.linkedin.venice.Arg
- ETLED_PROXY_USER_ACCOUNT - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- etledUserProxyAccount - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
- etledUserProxyAccount - Variable in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
- etledUserProxyAccount - Variable in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
-
If enabled regular ETL or future version ETL, this account name is part of path for where the ETLed snapshots will go.
- etlStoreConfig - Variable in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- ETLStoreConfig - Class in com.linkedin.venice.meta.systemstore.schemas
- ETLStoreConfig - Interface in com.linkedin.venice.meta
-
This interface defines all the public APIs, and if you need to add accessors to some new fields, this interface needs to be changed accordingly.
- ETLStoreConfig - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- ETLStoreConfig() - Constructor for class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
-
Default constructor.
- ETLStoreConfig(CharSequence, Boolean, Boolean) - Constructor for class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
-
All-args constructor.
- ETLStoreConfigImpl - Class in com.linkedin.venice.meta
-
A container of ETL Enabled Store related configurations.
- ETLStoreConfigImpl() - Constructor for class com.linkedin.venice.meta.ETLStoreConfigImpl
- ETLStoreConfigImpl(String, boolean, boolean) - Constructor for class com.linkedin.venice.meta.ETLStoreConfigImpl
- ETLStoreConfigRecord - Class in com.linkedin.venice.controller.kafka.protocol.admin
- ETLStoreConfigRecord() - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
-
Default constructor.
- ETLStoreConfigRecord(CharSequence, Boolean, Boolean) - Constructor for class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
-
All-args constructor.
- ETLStoreConfigSerializerMixin(String, boolean, boolean) - Constructor for class com.linkedin.venice.helix.StoreJSONSerializer.ETLStoreConfigSerializerMixin
- ETLUtils - Class in com.linkedin.venice.etl
- ETLUtils() - Constructor for class com.linkedin.venice.etl.ETLUtils
- etlValueSchemaTransformation - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- ETLValueSchemaTransformation - Enum Class in com.linkedin.venice.etl
-
In ETL jobs, when a "delete" record is seen, "value" is set to "null" and "DELETED_TS" is set to the offset where this delete record was seen.
- evaluate(double) - Method in class com.linkedin.venice.client.store.predicate.DoubleAnyOfPredicate
- evaluate(double) - Method in class com.linkedin.venice.client.store.predicate.DoubleEqualsPredicate
- evaluate(double) - Method in class com.linkedin.venice.client.store.predicate.DoubleGreaterOrEqualsPredicate
- evaluate(double) - Method in class com.linkedin.venice.client.store.predicate.DoubleGreaterThanPredicate
- evaluate(double) - Method in class com.linkedin.venice.client.store.predicate.DoubleLowerOrEqualsPredicate
- evaluate(double) - Method in class com.linkedin.venice.client.store.predicate.DoubleLowerThanPredicate
- evaluate(double) - Method in interface com.linkedin.venice.client.store.predicate.DoublePredicate
- evaluate(float) - Method in class com.linkedin.venice.client.store.predicate.FloatAnyOfPredicate
- evaluate(float) - Method in class com.linkedin.venice.client.store.predicate.FloatEqualsPredicate
- evaluate(float) - Method in class com.linkedin.venice.client.store.predicate.FloatGreaterOrEqualsPredicate
- evaluate(float) - Method in class com.linkedin.venice.client.store.predicate.FloatGreaterThanPredicate
- evaluate(float) - Method in class com.linkedin.venice.client.store.predicate.FloatLowerOrEqualsPredicate
- evaluate(float) - Method in class com.linkedin.venice.client.store.predicate.FloatLowerThanPredicate
- evaluate(float) - Method in interface com.linkedin.venice.client.store.predicate.FloatPredicate
- evaluate(int) - Method in class com.linkedin.venice.client.store.predicate.IntAnyOfPredicate
- evaluate(int) - Method in class com.linkedin.venice.client.store.predicate.IntEqualsPredicate
- evaluate(int) - Method in class com.linkedin.venice.client.store.predicate.IntGreaterOrEqualsPredicate
- evaluate(int) - Method in class com.linkedin.venice.client.store.predicate.IntGreaterThanPredicate
- evaluate(int) - Method in class com.linkedin.venice.client.store.predicate.IntLowerOrEqualsPredicate
- evaluate(int) - Method in class com.linkedin.venice.client.store.predicate.IntLowerThanPredicate
- evaluate(int) - Method in interface com.linkedin.venice.client.store.predicate.IntPredicate
- evaluate(long) - Method in class com.linkedin.venice.client.store.predicate.LongAnyOfPredicate
- evaluate(long) - Method in class com.linkedin.venice.client.store.predicate.LongEqualsPredicate
- evaluate(long) - Method in class com.linkedin.venice.client.store.predicate.LongGreaterOrEqualsPredicate
- evaluate(long) - Method in class com.linkedin.venice.client.store.predicate.LongGreaterThanPredicate
- evaluate(long) - Method in class com.linkedin.venice.client.store.predicate.LongLowerOrEqualsPredicate
- evaluate(long) - Method in class com.linkedin.venice.client.store.predicate.LongLowerThanPredicate
- evaluate(long) - Method in interface com.linkedin.venice.client.store.predicate.LongPredicate
- evaluate(Double) - Method in interface com.linkedin.venice.client.store.predicate.DoublePredicate
- evaluate(Float) - Method in interface com.linkedin.venice.client.store.predicate.FloatPredicate
- evaluate(Integer) - Method in interface com.linkedin.venice.client.store.predicate.IntPredicate
- evaluate(Long) - Method in interface com.linkedin.venice.client.store.predicate.LongPredicate
- evaluate(GenericRecord) - Method in class com.linkedin.venice.client.store.predicate.RecordFieldProjectionEqualsPredicate
- evaluate(T) - Method in class com.linkedin.venice.client.store.predicate.AndPredicate
- evaluate(T) - Method in class com.linkedin.venice.client.store.predicate.AnyOfPredicate
- evaluate(T) - Method in class com.linkedin.venice.client.store.predicate.EqualsPredicate
- evaluate(T) - Method in class com.linkedin.venice.client.store.predicate.OrPredicate
- evaluate(T) - Method in interface com.linkedin.venice.client.store.predicate.Predicate
- evaluateCompressionMetricCollectionEnabled(PushJobSetting, boolean) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
-
This functions evaluates the config
PushJobSetting.compressionMetricCollectionEnabled
based on the input data and other configs as an initial filter to disable this config for cases where we won't be able to collect this information or where it doesn't make sense to collect this information. - EVENT_THROTTLER_WITH_SILENT_REJECTION - Enum constant in enum class com.linkedin.venice.throttle.VeniceRateLimiter.RateLimiterType
- eventLoop() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- EventThrottler - Class in com.linkedin.venice.throttle
-
A class to throttle Events to a certain rate This class takes a maximum rate in events/sec and a minimum interval over which to check the rate.
- EventThrottler() - Constructor for class com.linkedin.venice.throttle.EventThrottler
- EventThrottler(long) - Constructor for class com.linkedin.venice.throttle.EventThrottler
- EventThrottler(long, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
- EventThrottler(long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
- EventThrottler(Time, long, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
- EventThrottler(Time, LongSupplier, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
- EventThrottler(LongSupplier, long, String, boolean, EventThrottlingStrategy) - Constructor for class com.linkedin.venice.throttle.EventThrottler
- EventThrottlingStrategy - Interface in com.linkedin.venice.throttle
-
This interface is used to abstract the strategy to handle the quota exceeding case.
- exceedQuota(long) - Method in class com.linkedin.venice.hadoop.InputStorageQuotaTracker
- EXCEPTION_THROWN - Enum constant in enum class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo.Result
- exceptionally(Function<Throwable, ? extends T>) - Method in class com.linkedin.alpini.base.concurrency.impl.AbstractAsyncFuture
- ExceptionCaptorNotifier - Class in com.linkedin.venice.utils
- ExceptionCaptorNotifier() - Constructor for class com.linkedin.venice.utils.ExceptionCaptorNotifier
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.BasicHttpServerCodec
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.ChannelInitializer
-
Handle the
Throwable
by logging and closing theChannel
. - exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.Http2ExceptionHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.alpini.netty4.handlers.StaleConnectionHandler
-
Calls
ChannelHandlerContext.fireExceptionCaught(Throwable)
to forward to the nextChannelHandler
in theChannelPipeline
. - exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.davinci.blobtransfer.client.P2PFileTransferClientHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.davinci.blobtransfer.server.P2PFileTransferServerHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServerHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionReportHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.listener.ErrorCatchingHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.listener.RouterRequestHttpHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.AdminOperationsHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.HealthCheckHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.MetaDataHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class com.linkedin.venice.router.RouterThrottleHandler
- exceptionCaught(ChannelHandlerContext, Throwable) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
- ExceptionClassAndCauseClassMatcher - Class in com.linkedin.venice.unit.matchers
- ExceptionClassAndCauseClassMatcher(Class, Class) - Constructor for class com.linkedin.venice.unit.matchers.ExceptionClassAndCauseClassMatcher
- ExceptionClassMatcher - Class in com.linkedin.venice.unit.matchers
- ExceptionClassMatcher(Class) - Constructor for class com.linkedin.venice.unit.matchers.ExceptionClassMatcher
- exceptionThrown - Variable in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
- ExceptionType - Enum Class in com.linkedin.venice.exceptions
-
Deprecated.since v0.2.620 Previously, this enum didn't have the @JsonEnumDefaultValue annotation. This annotation helps Jackson deserialize arbitrary values to a default value instead of throwing an Exception. Without this annotation, the enum is essentially non-evolvable since there may be many clients that are already running older code. Use
ErrorType
instead. - ExceptionUtil - Enum Class in com.linkedin.alpini.base.misc
- ExceptionUtils - Class in com.linkedin.venice.utils
-
Static utility functions to deal with exceptions.
- ExceptionUtils() - Constructor for class com.linkedin.venice.utils.ExceptionUtils
- ExceptionWithStatus - Exception in com.linkedin.alpini.base.misc
- ExceptionWithStatus(Class<STATUS>, STATUS, int, String) - Constructor for exception com.linkedin.alpini.base.misc.ExceptionWithStatus
- ExceptionWithStatus(Class<STATUS>, STATUS, int, String, Throwable) - Constructor for exception com.linkedin.alpini.base.misc.ExceptionWithStatus
- ExceptionWithStatus(Class<STATUS>, STATUS, int, String, Throwable, boolean, boolean) - Constructor for exception com.linkedin.alpini.base.misc.ExceptionWithStatus
- exec(Class, String...) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
- exec(Class, List<String>, List<String>) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
- exec(Class, List<String>, List<String>, boolean) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
- exec(Class, List<String>, List<String>, boolean, Optional<String>) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
- exec(Class, List<String>, List<String>, String, boolean, Optional<String>) - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
- execSyncOffsetCommandAsync(PubSubTopicPartition, StoreIngestionTask) - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
- execSyncOffsetCommandAsync(PubSubTopicPartition, StoreIngestionTask) - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
- execSyncOffsetCommandAsync(PubSubTopicPartition, StoreIngestionTask) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- execSyncOffsetFromSnapshotAsync(PubSubTopicPartition, PartitionTracker, StoreIngestionTask) - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
- execSyncOffsetFromSnapshotAsync(PubSubTopicPartition, PartitionTracker, StoreIngestionTask) - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
- execSyncOffsetFromSnapshotAsync(PubSubTopicPartition, PartitionTracker, StoreIngestionTask) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- ExecutableRequestBuilder<K,
R> - Interface in com.linkedin.venice.client.store - execute() - Method in class com.linkedin.venice.datarecovery.Command
- execute() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
- execute() - Method in class com.linkedin.venice.datarecovery.MonitorCommand
- execute() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
- execute() - Method in class com.linkedin.venice.system.store.ControllerClientBackedSystemSchemaInitializer
- execute() - Method in interface com.linkedin.venice.utils.TestUtils.NonDeterministicAssertion
- execute(DataRecoveryClient.DataRecoveryParams, StoreRepushCommand.Params) - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
- execute(DataValidationException) - Method in interface com.linkedin.davinci.validation.PartitionTracker.DIVErrorMetricCallback
- execute(Runnable) - Method in class com.linkedin.alpini.base.concurrency.TimeoutProcessor
- execute(Runnable) - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
-
Executes
command
with zero required delay. - execute(Runnable) - Method in class com.linkedin.alpini.base.registry.impl.ShutdownableExecutorServiceImpl
- execute(Runnable) - Method in class com.linkedin.alpini.router.impl.netty4.TimerTimeoutProcessor
- execute(String) - Method in class com.linkedin.venice.controller.init.ClusterLeaderInitializationManager
- execute(String) - Method in interface com.linkedin.venice.controller.init.ClusterLeaderInitializationRoutine
- execute(String) - Method in class com.linkedin.venice.controller.init.DelegatingClusterLeaderInitializationRoutine
- execute(String) - Method in class com.linkedin.venice.controller.init.PerClusterInternalRTStoreInitializationRoutine
- execute(String) - Method in class com.linkedin.venice.controller.init.SharedInternalRTStoreInitializationRoutine
- execute(String) - Method in class com.linkedin.venice.controller.init.SystemSchemaInitializationRoutine
- execute(String, int) - Method in interface com.linkedin.davinci.kafka.consumer.TopicPartitionConsumerFunction
- execute(Map<Integer, Schema>) - Method in class com.linkedin.venice.system.store.ControllerClientBackedSystemSchemaInitializer
- execute(Set<K>) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- execute(Set<K>) - Method in interface com.linkedin.venice.client.store.ExecutableRequestBuilder
-
Send compute request to Venice, and this should be the last step of the compute specification.
- EXECUTE_DATA_RECOVERY - Enum constant in enum class com.linkedin.venice.Command
- executeGet(String, String, QueryParams, Class<T>) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
- executeGet(String, String, QueryParams, Class<T>, int) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
- executePost(String, String, QueryParams, Class<T>) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
- executePost(String, String, QueryParams, Class<T>, int) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
- executePost(String, String, QueryParams, Class<T>, int, byte[]) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
-
This method shoves the POST string query params into the URL so the body will only contain the byte array data to make processing/deserializing easier.
- executeRequest(HttpRequestBase, Class<T>, int) - Method in class com.linkedin.venice.controllerapi.ControllerTransport
- executeShellCommand(String) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- executeStateTransition(Message, NotificationContext, Runnable) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- executeStateTransition(Message, NotificationContext, Runnable, boolean) - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- executeUnderConditionalLock(Runnable, BooleanSupplier, Object) - Static method in class com.linkedin.venice.utils.concurrent.ConcurrencyUtils
- executeUnderLock(Runnable, Runnable, BooleanSupplier, Object) - Static method in class com.linkedin.venice.utils.concurrent.ConcurrencyUtils
- executeWithFilter(Predicate<GenericRecord>, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
- executeWithFilter(Predicate<GenericRecord>, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV4
- executeWithFilter(Predicate<GenericRecord>, StreamingCallback<GenericRecord, GenericRecord>) - Method in interface com.linkedin.venice.client.store.ComputeRequestBuilder
-
Streaming interface that sends compute request to Venice, which will be executed on values whose keys satisfy the given predicate.
- executeWithMaxAttempt(VeniceCheckedRunnable, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Runnable
with fixed delay with a maximum attempt. - executeWithMaxAttempt(VeniceCheckedRunnable, int, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Runnable
with fixed delay with a maximum attempt. - executeWithMaxAttempt(VeniceCheckedSupplier<T>, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Supplier
with fixed delay with a maximum attempt. - executeWithMaxAttempt(VeniceCheckedSupplier<T>, int, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Supplier
with fixed delay with a maximum attempt. - executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedRunnable, int, Duration, Duration, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Runnable
with exponential backoff. - executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedRunnable, int, Duration, Duration, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Runnable
with exponential backoff. - executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedSupplier<T>, int, Duration, Duration, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Supplier
with exponential backoff. - executeWithMaxAttemptAndExponentialBackoff(VeniceCheckedSupplier<T>, int, Duration, Duration, Duration, List<Class<? extends Throwable>>, RetryUtils.IntermediateFailureHandler) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Supplier
with exponential backoff. - executeWithMaxAttemptAndExponentialBackoffNoLog(VeniceCheckedSupplier<T>, int, Duration, Duration, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
- executeWithMaxAttemptNoIntermediateLogging(VeniceCheckedRunnable, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Runnable
with fixed delay with a maximum attempt. - executeWithMaxRetriesAndFixedAttemptDuration(VeniceCheckedSupplier<T>, int, Duration, List<Class<? extends Throwable>>) - Static method in class com.linkedin.venice.utils.RetryUtils
-
Execute a
Supplier
with maximum retries and fix duration per retry attempt. - EXECUTION - Enum constant in enum class com.linkedin.venice.Arg
- EXECUTION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- EXECUTION_ID - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- EXECUTION_IDS - Static variable in class com.linkedin.venice.zk.VeniceZkPaths
- executionId - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
-
ID of a command execution which is used to query the status of this command.
- EXECUTIONID_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- ExecutionIdAccessor - Interface in com.linkedin.venice.controller
-
Accessor user to get/update the last execution id and the generated id from a storage.
- ExecutionStatus - Enum Class in com.linkedin.venice.pushmonitor
-
Status of executing off-line push.
- ExecutionStatusWithDetails - Class in com.linkedin.venice.pushmonitor
- ExecutionStatusWithDetails(ExecutionStatus) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
- ExecutionStatusWithDetails(ExecutionStatus, String) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
- ExecutionStatusWithDetails(ExecutionStatus, String, boolean) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
- ExecutionStatusWithDetails(ExecutionStatus, String, boolean, Long) - Constructor for class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
- executor(CHC) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- executor(ChannelHandlerContext) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
- executor(Executor) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
- executor(Executor) - Method in interface com.linkedin.alpini.router.impl.Router.Builder
- EXECUTOR_GROUP_ATTRIBUTE_KEY - Static variable in class com.linkedin.alpini.netty4.misc.NettyUtils
- executorFailure(ChannelPromise, RejectedExecutionException) - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
- executorGroup(Channel) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
- executorGroup(ChannelPipeline) - Static method in class com.linkedin.alpini.netty4.misc.NettyUtils
- Executors - Enum Class in com.linkedin.alpini.base.concurrency
-
Factory and utility methods for
Executor
,ExecutorService
,ScheduledExecutorService
,ThreadFactory
, andCallable
classes defined in this package. - executorService - Variable in class com.linkedin.davinci.helix.AbstractStateModelFactory
- executorService - Variable in class com.linkedin.venice.controller.multitaskscheduler.ScheduledTaskManager
- ExecutorService - Interface in com.linkedin.alpini.base.concurrency
-
An analog to
ExecutorService
except that the futures returned areAsyncFuture
s. - existingHttpPipelineInitializer(Consumer<ChannelPipeline>) - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- exists(ZkBaseDataAccessor<T>, String) - Static method in class com.linkedin.venice.utils.HelixUtils
- exit() - Method in enum class com.linkedin.venice.samza.SamzaExitMode
- exit(String) - Static method in class com.linkedin.venice.utils.Utils
-
Print an error and exit with error code 1
- exit(String, int) - Static method in class com.linkedin.venice.utils.Utils
-
Print an error and exit with the given error code
- exitValue() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
- expand(PBegin) - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- EXPECTATION_FAILED - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- EXPECTED_PROTOCOL - Static variable in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
- EXPECTED_ROUTER_COUNT - Enum constant in enum class com.linkedin.venice.Arg
- EXPECTED_ROUTER_COUNT - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- expectedMapping() - Method in class com.linkedin.venice.utils.VeniceEnumValueTest
- Experimental - Annotation Interface in com.linkedin.venice.annotation
- exportOtelMetricsToEndpoint() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- exportOtelMetricsToLog() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- EXTENDED_INPUT_DATA_SCHEMA_VALIDATION_FAILED - Enum constant in enum class com.linkedin.venice.PushJobCheckpoints
- EXTENDED_SCHEMA_VALIDITY_CHECK_ENABLED - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- ExtendedResourcePathParser<P extends ResourcePath<K>,
K, HTTP_REQUEST extends BasicRequest> - Interface in com.linkedin.alpini.router.api -
Created by acurtis on 6/12/17.
- extendedSchemaValidityCheckEnabled - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- EXTERNALVIEW - Enum constant in enum class com.linkedin.venice.helix.HelixViewPropertyType
- extinguish() - Method in class com.linkedin.venice.controller.spark.VeniceSparkEmbeddedJettyServer
- EXTRA_COMMAND_ARGS - Enum constant in enum class com.linkedin.venice.Arg
- extract(byte[], Iterator<byte[]>, Iterator<Long>, Schema, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputReducer
- extract(byte[], Iterator<byte[]>, Iterator<Long>, Schema, DataWriterTaskTracker) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
- EXTRACT_VENICE_ZK_PATHS - Enum constant in enum class com.linkedin.venice.Command
- extractAndSetOtelConfigs(Map<String, String>) - Method in class com.linkedin.venice.stats.VeniceMetricsConfig.Builder
-
Extract and set otel configs
- extractAvroSubSchema(Schema, String) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
- extractAvroSubSchema(Schema, String) - Method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
- extractAvroSubSchema(Schema, String) - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
- extractByteArray(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
- extractByteArray(ByteBuffer, byte[], int, int) - Static method in class com.linkedin.venice.utils.ByteUtils
-
Extract the data in the ByteBuffer into the destination array by copying "length" bytes from the source buffer into the given array, starting at the current position of the source buffer and at the given offset in the destination array.
- extractClientCert(ChannelHandlerContext) - Static method in class com.linkedin.venice.listener.ServerHandlerUtils
- extractConcurrentProducerConfig(Properties, VeniceWriterOptions.Builder) - Static method in class com.linkedin.venice.samza.VeniceSystemProducer
- extractGrpcClientCert(ServerCall<?, ?>) - Static method in class com.linkedin.venice.grpc.GrpcUtils
- extractIncPushStatusWriteMode(String) - Method in class com.linkedin.davinci.config.VeniceServerConfig
- extractOffsetVectorFromMessage(int, int, ByteBuffer) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- extractOffsetVectorFromRmd(GenericRecord) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
- extractOffsetVectorSumFromRmd(GenericRecord) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
- extractOptionalParamsFromRequestTopicRequest(Request, RequestTopicForPushRequest, boolean) - Static method in class com.linkedin.venice.controller.server.CreateVersion
- extractPushType(String) - Static method in enum class com.linkedin.venice.meta.Version.PushType
-
Extracts the PushType from its string name.
- extractQueryParameters(HttpRequest) - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
-
We provide this method as a utility function as opposed to storing the query parameters in this class.
- extractQueryParamsFromRequest(Map<String, String[]>, ControllerResponse) - Static method in class com.linkedin.venice.utils.Utils
- extractRegularStoreName(String) - Method in enum class com.linkedin.venice.common.VeniceSystemStoreType
-
This function is to extract the regular store name from the system store name.
- extractSslHandler(ChannelHandlerContext) - Method in class com.linkedin.venice.listener.ServerConnectionStatsHandler
- extractSslHandler(ChannelHandlerContext) - Static method in class com.linkedin.venice.listener.ServerHandlerUtils
- extractStoreName(QueryAction, String[]) - Method in class com.linkedin.venice.listener.ServerStoreAclHandler
- extractStoreName(RouterResourceType, String[]) - Method in class com.linkedin.venice.router.acl.RouterStoreAclHandler
-
Extract the store name from the incoming resource name.
- extractStoreName(REQUEST_TYPE, String[]) - Method in class com.linkedin.venice.acl.handler.AbstractStoreAclHandler
- extractSystemStoreType(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
- extractTempRMDSSTFileNo(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- extractTempSSTFileNo(String) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- extractTimestampFromRmd(GenericRecord) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
- extractUserStoreName(String) - Static method in enum class com.linkedin.venice.common.VeniceSystemStoreType
-
Extract the corresponding user store name from the given store name if it happens to be a system store.
- extractVenicePaths(String, String, Set<String>, String) - Static method in class com.linkedin.venice.ZkCopier
-
Extract Venice-specific paths from an input text file to an output text file.
- extractVersionTopicsToCleanup(Admin, Map<PubSubTopic, Long>, int, int) - Static method in class com.linkedin.venice.controller.kafka.TopicCleanupService
-
Filter Venice version topics so that the returned topics satisfying the following conditions: topic is truncated based on retention time.
- extractViewPartitionMap(PubSubMessageHeaders) - Static method in class com.linkedin.venice.views.ViewUtils
F
- FABRIC - Enum constant in enum class com.linkedin.venice.Arg
- FABRIC - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- FABRIC_A - Enum constant in enum class com.linkedin.venice.Arg
- FABRIC_A - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- FABRIC_B - Enum constant in enum class com.linkedin.venice.Arg
- FABRIC_B - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- FABRICTOEXECUTIONSTATUSMAP_FIELD_NUMBER - Static variable in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- factory() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- factory(Class<F>) - Method in class com.linkedin.alpini.base.registry.ResourceRegistry
-
Return a factory which implements the requested factory class F.
- factory(Class<F>) - Method in class com.linkedin.alpini.router.impl.netty4.Router4
- FAIL - Enum constant in enum class com.linkedin.venice.sql.AvroToSQL.UnsupportedTypeHandling
- FAIL - Enum constant in enum class com.linkedin.venice.stats.dimensions.VeniceResponseStatusCategory
- FAIL_FAST_WHEN_LIMIT_EXCEEDED - Enum constant in enum class com.linkedin.alpini.netty4.handlers.ConnectionHandleMode
-
Fail fast when the connection limit is exceeded.
- failed(Throwable) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
-
Create a new failed future.
- FAILED - Enum constant in enum class com.linkedin.venice.jobs.ComputeJob.Status
-
A job that failed during it's execution
- FAILED - Enum constant in enum class com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
- FAILED - Enum constant in enum class com.linkedin.venice.utils.VeniceResourceCloseResult
- FAILED_DEPENDENCY - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- FAILED_VERIFICATION - Enum constant in enum class com.linkedin.venice.jobs.ComputeJob.Status
-
A job that has completed execution but failed verification
- FailedAsyncFuture<T> - Class in com.linkedin.alpini.base.concurrency.impl
- FailedAsyncFuture(Throwable) - Constructor for class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
- failedLockAcquisition - Variable in class com.linkedin.venice.stats.VeniceLockStats
- failureDetails - Variable in class com.linkedin.venice.status.protocol.PushJobDetails
- failureString(String) - Method in class com.linkedin.venice.controller.AuditInfo
- FakeCompressingSchema - Class in com.linkedin.venice.compression.protocol
-
This record is only used to training a ZSTD dictionary on a small amount of generated avro data
- FakeCompressingSchema() - Constructor for class com.linkedin.venice.compression.protocol.FakeCompressingSchema
-
Default constructor.
- FakeCompressingSchema(Integer, CharSequence) - Constructor for class com.linkedin.venice.compression.protocol.FakeCompressingSchema
-
All-args constructor.
- FALSE - Static variable in interface com.linkedin.venice.utils.lazy.Lazy
- FAST_AVRO_FIELD_LIMIT_PER_METHOD - Static variable in class com.linkedin.venice.ConfigKeys
-
Config to control the maximum number of fields per method in a fast-avro generated deserializer.
- FAST_CLIENT - Enum constant in enum class com.linkedin.venice.stats.ClientType
- FastAvroGenericDeserializer<V> - Class in com.linkedin.venice.serializer
-
* This class is leveraging linkedin-avro-fastserde-impl to speed up deserialization.
- FastAvroGenericDeserializer(Schema, Schema, FastSerdeCache) - Constructor for class com.linkedin.venice.serializer.FastAvroGenericDeserializer
- FastAvroSerializer<K> - Class in com.linkedin.venice.serializer
-
This class is leveraging linkedin-avro-fastserde-impl to speed up serialization, and so far it doesn't work for Avro-1.4, and it will fail back to regular Avro.
- FastAvroSerializer(Schema, FastSerdeCache) - Constructor for class com.linkedin.venice.serializer.FastAvroSerializer
- FastAvroSerializer(Schema, FastSerdeCache, boolean) - Constructor for class com.linkedin.venice.serializer.FastAvroSerializer
- FastAvroSpecificDeserializer<T extends org.apache.avro.specific.SpecificRecord> - Class in com.linkedin.venice.serializer
-
This class is leveraging linkedin-avro-fastserde-impl to speed up deserialization.
- FastAvroSpecificDeserializer(Schema, Class<T>, FastSerdeCache) - Constructor for class com.linkedin.venice.serializer.FastAvroSpecificDeserializer
- FASTCLIENT_HTTP_VARIANTS - Static variable in class com.linkedin.venice.fastclient.utils.ClientTestUtils
- FastClientStats - Class in com.linkedin.venice.fastclient.stats
- FastClientStats.FastClientTehutiMetricName - Enum Class in com.linkedin.venice.fastclient.stats
-
Metric names for tehuti metrics used in this class.
- FastDeserializerGeneratorAccessor - Class in com.linkedin.avro.fastserde
-
Only for the sake of accessing a package-private method...
- FastDeserializerGeneratorAccessor() - Constructor for class com.linkedin.avro.fastserde.FastDeserializerGeneratorAccessor
- FASTER_OF_TWO_ONLINE - Enum constant in enum class com.linkedin.venice.meta.ReadStrategy
- FastSerializerDeserializerFactory - Class in com.linkedin.venice.serializer
- FastSerializerDeserializerFactory() - Constructor for class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
- FATAL_DATA_VALIDATION_ERROR - Static variable in class com.linkedin.venice.utils.Utils
- FATAL_DATA_VALIDATION_FAILURE_TOPIC_RETENTION_MS - Static variable in class com.linkedin.venice.ConfigKeys
- FatalDataValidationException - Exception in com.linkedin.venice.exceptions.validation
-
This class encompasses all error conditions which: 1.
- FatalDataValidationException(Lazy<String>) - Constructor for exception com.linkedin.venice.exceptions.validation.FatalDataValidationException
- FatalDataValidationException(String) - Constructor for exception com.linkedin.venice.exceptions.validation.FatalDataValidationException
- fetch() - Method in class com.linkedin.venice.ControlMessageDumper
-
1.
- fetchAndCacheStorePropertiesWithICProvider(String) - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- fetchAndProcess(long, long, int) - Method in class com.linkedin.venice.KafkaTopicDumper
-
Fetches and processes messages from a given PubSub topic partition between specified offsets.
- fetchKeySchema() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
- fetchKeySchema() - Method in interface com.linkedin.venice.hadoop.schema.SchemaSource
- fetchRmdSchemas() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
-
Fetch all rmd schemas under the
HDFSSchemaSource.rmdSchemaDir
if available. - fetchRmdSchemas() - Method in interface com.linkedin.venice.hadoop.schema.SchemaSource
- fetchStoreConfigFromRemote(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- fetchStoreConfigFromRemote(String) - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- fetchStoreConfigFromRemote(String) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
- fetchStoreFromRemote(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- fetchStoreFromRemote(String, String) - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- fetchStoreFromRemote(String, String) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
- fetchStoreProperties(String) - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- fetchValueSchemas() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
-
Fetch all value schemas under the
HDFSSchemaSource.rmdSchemaDir
if available. - fetchValueSchemas() - Method in interface com.linkedin.venice.hadoop.schema.SchemaSource
- field - Variable in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
-
The field in the original value record, which will used to execute cosine-similarity calculation
- field - Variable in class com.linkedin.venice.compute.protocol.request.Count
-
The field name in the original value record of type array or map, which will used to execute count operation on
- field - Variable in class com.linkedin.venice.compute.protocol.request.DotProduct
-
The field in the original value record, which will used to execute dot-product calculation
- field - Variable in class com.linkedin.venice.compute.protocol.request.HadamardProduct
-
The field in the original value record, which will used to execute hadamard-product calculation
- FILE - Enum constant in enum class com.linkedin.davinci.blobtransfer.BlobTransferUtils.BlobTransferType
- FILE_KEY_SCHEMA - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- FILE_VALUE_SCHEMA - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- fillInStackTrace() - Method in exception com.linkedin.alpini.base.misc.Http2TooManyStreamsException
- filter(Predicate<? super C>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
- filter(Predicate<? super T>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
-
If a value is initialized, and the value matches the given predicate, return an
Optional
describing the value, otherwise return an emptyOptional
. - filter(Predicate<? super T>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
- filter(Iterator<T>, Predicate<? super T>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
- filterCanonicalizedSchemas(SchemaEntry, Collection<SchemaEntry>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
-
Filter the given schemas using the referenceSchema and AvroCompatibilityHelper.
- FilterChain<INPUT_VALUE> - Class in com.linkedin.venice.hadoop
-
The FilterChain class takes a list of
AbstractVeniceFilter
to assemble a filter chain to manage the life cycles' of filters and perform filtering based on the order of filters. - FilterChain() - Constructor for class com.linkedin.venice.hadoop.FilterChain
- FilterChain(AbstractVeniceFilter<INPUT_VALUE>...) - Constructor for class com.linkedin.venice.hadoop.FilterChain
- filterDisallowedCiphersuites(String[]) - Static method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
- filterDisallowedCiphersuites(String[]) - Static method in class com.linkedin.venice.security.DefaultSSLFactory
- FilteringPollStrategy - Class in com.linkedin.venice.unit.kafka.consumer.poll
-
A
PollStrategy
implementation which can pluck out records from the stream. - FilteringPollStrategy(AbstractPollStrategy, Set<PubSubTopicPartitionOffset>) - Constructor for class com.linkedin.venice.unit.kafka.consumer.poll.FilteringPollStrategy
- filterSchemas(SchemaEntry, Collection<SchemaEntry>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
-
Filter the given schemas using the referenceSchema and the underlying
Schema.equals
method. - finalizeCheckpoint() - Method in class com.linkedin.venice.beam.consumer.VeniceCheckpointMark
- finalizeExpectedChecksum() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- finalSegment - Variable in class com.linkedin.venice.kafka.protocol.EndOfSegment
-
This field is set to true when the producer knows that there is no more data coming from its data source after this EndOfSegment.
- find(D2TransportClient, String) - Method in class com.linkedin.venice.client.store.D2ServiceDiscovery
- find(D2TransportClient, String, boolean) - Method in class com.linkedin.venice.client.store.D2ServiceDiscovery
- find(ControllerClient, PubSubConsumerAdapter, String, String, long, long, long) - Static method in class com.linkedin.venice.TopicMessageFinder
- find(String) - Method in interface com.linkedin.venice.utils.PathResourceRegistry
- find(String) - Method in class com.linkedin.venice.utils.TrieBasedPathResourceRegistry
- findAllBootstrappingVersions(String) - Method in interface com.linkedin.venice.controller.Admin
-
Find the store versions which have at least one bootstrap replica.
- findAllBootstrappingVersions(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- findAllBootstrappingVersions(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- findFoldersWithFileExtension(File, String) - Static method in class com.linkedin.venice.utils.TestUtils
- findHosts(String, String, String, int, HostHealthMonitor<Instance>) - Method in class com.linkedin.venice.router.api.VeniceHostFinder
- findHosts(String, String, String, HostHealthMonitor<Instance>, VeniceRole) - Method in class com.linkedin.venice.router.api.VeniceHostFinder
-
This parameter list is based on the router API.
- findHosts(String, String, String, HostHealthMonitor<H>, R) - Method in interface com.linkedin.alpini.router.api.HostFinder
-
Find hosts that can serve the given database and partition with one of the roles passed.
- findPartitioner(String, int) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
-
Query the map to find the partitioner in need.
- findPartitionIdForKey(ControllerClient, String, int, String, String) - Static method in class com.linkedin.venice.TopicMessageFinder
- findPartitionName(Pair<String, K>) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
- findPartitionName(String, RouterKey) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
- findPartitionName(String, K) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
-
Returns the name of partition for the given key within the given table.
- findPartitionName(String, K) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
-
Returns the name of partition for the given key within the given table.
- findPartitionName(String, K) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- findPartitionNumber(RouterKey, int, String, int) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
- findPartitionNumber(K, int, String, int) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
-
Venice-specific API for finding the partition number without the added overhead of parsing a partition name.
- findPartitionNumber(K, int, String, int) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
-
Venice-specific API for finding the partition number without the added overhead of parsing a partition name.
- findStartedAndCompletedStatus() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- finish() - Method in class com.linkedin.venice.compression.ReusableGzipOutputStream
-
Finishes writing compressed data to the output stream without closing the underlying stream.
- finishRequest(long, int, double) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupLeastLoadedStrategy
- finishRequest(long, int, double) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupRoundRobinStrategy
- finishRequest(long, int, double) - Method in interface com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategy
-
Notify the corresponding Helix Group that the request is completed, and the implementation will decide whether any cleanup is required or not.
- finishRequest(long, int, double) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
- first() - Method in enum class com.linkedin.venice.Arg
- fiveBoolean() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- fixMalformedMetricName(String) - Static method in class com.linkedin.venice.stats.TehutiUtils
-
A valid metric name needs to pass the test in
ObjectName
. - fixMissingFields() - Method in class com.linkedin.venice.meta.AbstractStore
- fixMissingFields() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- fixMissingFields() - Method in interface com.linkedin.venice.meta.Store
- fixRetryRequestForSubPath(Map<RouterKey, ComputeRouterRequestKeyV1>) - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
-
If the parent request is a retry request, the sub-request generated by scattering-gathering logic should be retry request as well.
- fixRetryRequestForSubPath(Map<RouterKey, MultiGetRouterRequestKeyV1>) - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
-
If the parent request is a retry request, the sub-request generated by scattering-gathering logic should be retry request as well.
- fixRetryRequestForSubPath(Map<RouterKey, K>) - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- FLAT_JSON - Enum constant in enum class com.linkedin.venice.Arg
- flatMap(Function<? super C, Optional<U>>) - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
- flatMap(Function<? super T, Optional<U>>) - Method in interface com.linkedin.venice.utils.lazy.Lazy
-
If a value is initialized, apply the provided
Optional
-bearing mapping function to it, return that result, otherwise return an emptyOptional
. - flatMap(Function<? super T, Optional<U>>) - Method in class com.linkedin.venice.utils.lazy.LazyImpl
- flatMap(Iterator<T>, Function<? super T, Iterator<? extends R>>) - Static method in class com.linkedin.alpini.base.misc.IteratorUtil
- flatViewConfigMapString(Map<String, ViewConfig>) - Static method in class com.linkedin.venice.views.ViewUtils
- FLOAT32 - Enum constant in enum class com.linkedin.venice.schema.vson.VsonTypes
-
Deprecated.
- FLOAT64 - Enum constant in enum class com.linkedin.venice.schema.vson.VsonTypes
-
Deprecated.
- FloatAnyOfPredicate - Class in com.linkedin.venice.client.store.predicate
- FloatEqualsPredicate - Class in com.linkedin.venice.client.store.predicate
- FloatGreaterOrEqualsPredicate - Class in com.linkedin.venice.client.store.predicate
- FloatGreaterThanPredicate - Class in com.linkedin.venice.client.store.predicate
- FloatLowerOrEqualsPredicate - Class in com.linkedin.venice.client.store.predicate
- FloatLowerThanPredicate - Class in com.linkedin.venice.client.store.predicate
- FloatPredicate - Interface in com.linkedin.venice.client.store.predicate
- flush() - Method in class com.linkedin.venice.hadoop.task.datawriter.CompositeVeniceWriter
- flush() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
- flush() - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
- flush() - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterConcurrentDelegator
- flush() - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterDelegator
- flush() - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
- flush() - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
- flush() - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
- flush() - Method in class com.linkedin.venice.writer.VeniceWriter
-
Call flush on the internal
PubSubProducerAdapter
. - flush() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- flush(ChannelHandlerContext) - Method in class com.linkedin.venice.router.streaming.NettyChunkedWriteHandler
- flush(String) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
-
Flushing the data to Venice store in case VeniceSystemProducer buffers message.
- flush0(ChannelHandlerContext) - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler.EspressoHttp2MultiplexHandlerStreamChannel
- FOLLOWER_BYTES_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
- FOLLOWER_OFFSET_LAG - Static variable in class com.linkedin.davinci.stats.IngestionStats
- FOLLOWER_RECORDS_CONSUMED_METRIC_NAME - Static variable in class com.linkedin.davinci.stats.IngestionStats
- FORBIDDEN - Enum constant in enum class com.linkedin.venice.acl.handler.AccessResult
- FORBIDDEN - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- FORCE - Enum constant in enum class com.linkedin.venice.Arg
- FORCE_LEADER_ERROR_REPLICA_FAIL_OVER_ENABLED - Static variable in class com.linkedin.venice.ConfigKeys
-
Config to enable single leader replica disabling.
- forceAddVersion(Version, boolean) - Method in class com.linkedin.venice.meta.AbstractStore
- forceAddVersion(Version, boolean) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- forceAddVersion(Version, boolean) - Method in interface com.linkedin.venice.meta.Store
- ForceCloseOnWriteTimeoutHandler - Class in io.netty.handler.timeout
-
If a remote peer is unresponsive due to CPU throttling, GC or otherwise, ForceCloseOnWriteTimeoutHandler closes the connection on write timeout, the time out by default is 30 sec.
- ForceCloseOnWriteTimeoutHandler(int) - Constructor for class io.netty.handler.timeout.ForceCloseOnWriteTimeoutHandler
- forceStart() - Method in class com.linkedin.venice.d2.D2Server
-
Manually start the d2 server.
- forceStart() - Method in class com.linkedin.venice.d2.D2ServerManager
- forceStorageEngineCleanup(String) - Method in class com.linkedin.davinci.storage.StorageService
-
This function is used to forcely clean up all the databases belonging to .
- forClient() - Static method in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecBuilder
-
Creates a builder for an HTTP/2 client.
- forEach(BiConsumer<? super K, ? super V>) - Method in class com.linkedin.davinci.utils.IndexedHashMap
- forEach(Consumer<? super E>) - Method in class com.linkedin.venice.utils.SparseConcurrentList
- forEachBeforeChunkAggregator(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- forEachBeforeHttpRequestHandler(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- forEachBeforeHttpServerCodec(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- forEachBeforeIdleStateHandler(Consumer<Pair<String, ?>>) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- forField(Class<? super T>, String) - Static method in interface com.linkedin.alpini.base.misc.TypedFieldAccessor
- forField(Field) - Static method in class com.linkedin.alpini.base.misc.SlowFieldAccessor
- forField(Field) - Method in class com.linkedin.alpini.base.misc.SlowFieldAccessorHelper
- forField(Field) - Static method in interface com.linkedin.alpini.base.misc.TypedFieldAccessor
- forField(Field) - Method in class com.linkedin.alpini.base.misc.TypedFieldAccessorHelper
- FORKED_PROCESS_METADATA_FILENAME - Static variable in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- ForkedJavaProcess - Class in com.linkedin.venice.utils
-
Adapted from https://stackoverflow.com/a/723914/791758
- ForkedJavaProcess.LogInfo - Class in com.linkedin.venice.utils
- format(Object) - Static method in class com.linkedin.venice.schema.vson.VsonSchema
-
Deprecated.
- FORMAT_KEY - Static variable in class com.linkedin.venice.RequestConstants
- formatDate(Date) - Static method in enum class com.linkedin.alpini.base.misc.HeaderUtils
- formatTo(StringBuilder) - Method in class com.linkedin.alpini.base.misc.Msg
- forName(String) - Static method in enum class com.linkedin.venice.pubsub.api.PubSubSecurityProtocol
- forNumber(int) - Static method in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
- forServer() - Static method in class io.netty.handler.codec.http2.EspressoHttp2FrameCodecBuilder
-
Creates a builder for a HTTP/2 server.
- FORWARD - Enum constant in enum class com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
-
Clients using the old schema should be able to read data written with the new schema.
- forwardPut(K, V, int, Set<Integer>) - Method in class com.linkedin.venice.writer.ComplexVeniceWriter
-
Used during NR pass-through in remote region to forward records or chunks of records to corresponding view partition based on provided view partition map.
- FOUND - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- fourBoolean() - Static method in class com.linkedin.venice.utils.DataProviderUtils
- freeze() - Static method in enum class com.linkedin.alpini.base.misc.Time
- freeze(long, long) - Static method in enum class com.linkedin.alpini.base.misc.Time
- FREEZE_INGESTION_IF_READY_TO_SERVE_OR_LOCAL_DATA_EXISTS - Static variable in class com.linkedin.venice.ConfigKeys
-
This config will determine whether live update will be suppressed.
- freezeIngestionIfReadyToServeOrLocalDataExists() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- fromBase64(String) - Static method in class com.linkedin.venice.router.api.RouterKey
- fromCharSequenceMap(Map<CharSequence, CharSequence>) - Static method in class com.linkedin.venice.utils.VeniceProperties
- fromDisplay(String) - Static method in enum class com.linkedin.venice.schema.vson.VsonTypes
-
Deprecated.
- fromHexString(String) - Static method in class com.linkedin.venice.utils.ByteUtils
-
Translate the given hexidecimal string into a byte array
- fromHostAndPort(String, int) - Static method in class com.linkedin.venice.meta.Instance
- fromInt(int) - Static method in enum class com.linkedin.venice.meta.BackupStrategy
- fromNodeId(String) - Static method in class com.linkedin.venice.meta.Instance
- fromPartitionStatus(PartitionStatus) - Static method in class com.linkedin.venice.pushmonitor.ReadOnlyPartitionStatus
- fromPropertiesOrDefault(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubPositionTypeRegistry
-
Creates a
PubSubPositionTypeRegistry
from the givenVeniceProperties
by reading the config keyConfigKeys.PUBSUB_TYPE_ID_TO_POSITION_CLASS_NAME_MAP
. - fromProps(VeniceProperties) - Static method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroRecordReader
- fromSchema(Schema) - Static method in enum class com.linkedin.venice.etl.ETLValueSchemaTransformation
- fromSchemaStr(String) - Static method in class com.linkedin.venice.schema.vson.VsonAvroSerializer
-
Deprecated.
- fromStepNumber(int) - Static method in enum class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Step
- fromStore(Store) - Static method in class com.linkedin.venice.meta.StoreInfo
- fromString(String) - Static method in class com.linkedin.venice.router.api.RouterKey
- fromTransportClientWithRoute(TransportClientResponse, String, CompletableFuture<Integer>) - Static method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
- FROZEN - Enum constant in enum class com.linkedin.venice.controllerapi.routes.V1Put
- FROZEN - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- FULL - Enum constant in enum class com.linkedin.venice.schema.avro.DirectionalSchemaCompatibilityType
-
Both backward and forward compatible.
- FULL_PUSH - Enum constant in enum class com.linkedin.venice.common.PushStatusStoreUtils.PushStatusKeyType
- FullHttpMultiPart - Interface in com.linkedin.alpini.netty4.misc
-
Created by acurtis on 3/22/17.
- FullHttpMultiPartRequest - Interface in com.linkedin.alpini.netty4.misc
-
Created by acurtis on 3/27/17.
- FULLLY_REPLICATED - Enum constant in enum class com.linkedin.venice.meta.StoreStatus
- FusedSslHandler - Class in com.linkedin.alpini.netty4.ssl
-
An implementation of SslHandler which limits the number of objects held within the pendingUnencryptedWrites queue.
- FusedSslHandler(SSLEngine) - Constructor for class com.linkedin.alpini.netty4.ssl.FusedSslHandler
- FusedSslHandler(SSLEngine, Executor) - Constructor for class com.linkedin.alpini.netty4.ssl.FusedSslHandler
- FusedSslHandler.OverflowException - Exception in com.linkedin.alpini.netty4.ssl
- FUTURE - Enum constant in enum class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext.VersionRole
- FUTURE_VERSION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- FUTURE_VERSION_ETL_ENABLED - Enum constant in enum class com.linkedin.venice.Arg
- FUTURE_VERSION_ETL_ENABLED - Static variable in class com.linkedin.venice.controllerapi.ControllerApiConstants
- Futures - Class in com.linkedin.alpini.netty4.misc
-
Created by acurtis on 2/1/17.
- futureVersionETLEnabled - Variable in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
- futureVersionETLEnabled - Variable in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
- futureVersionETLEnabled - Variable in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
-
Whether or not enable future version ETL - the version that might come online in future - for this store.
G
- GATEWAY_TIMEOUT - Enum constant in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- gatewayTimeout() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
- gatewayTimeout() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- GENERAL_ERROR - Enum constant in enum class com.linkedin.venice.exceptions.ErrorType
- GENERAL_ERROR - Enum constant in enum class com.linkedin.venice.exceptions.ExceptionType
-
Deprecated.
- GENERAL_ERROR - Enum constant in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
GENERAL_ERROR = 7;
- GENERAL_ERROR_VALUE - Static variable in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
-
GENERAL_ERROR = 7;
- GENERATE_PARTIAL_UPDATE_RECORD_FROM_INPUT - Static variable in class com.linkedin.venice.vpj.VenicePushJobConstants
- generateComputeRequest(SchemaAndToString, boolean) - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- GeneratedSchemaEntry - Class in com.linkedin.venice.schema
-
This is an abstract class which represents a generic class associating a generated schema id with it's corresponding value schema id
- GeneratedSchemaEntry(int, int, byte[]) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaEntry
- GeneratedSchemaEntry(int, int, String) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaEntry
- GeneratedSchemaEntry(int, int, Schema) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaEntry
- GeneratedSchemaID - Class in com.linkedin.venice.schema
-
In Venice, some schemas are generated, by deriving them from value schemas.
- GeneratedSchemaID(int, int) - Constructor for class com.linkedin.venice.schema.GeneratedSchemaID
- generateFileChecksum(Path) - Static method in class com.linkedin.davinci.blobtransfer.BlobTransferUtils
-
Generate MD5 checksum for a file
- generateHeartbeatMessage(CheckSumType) - Static method in class com.linkedin.venice.writer.VeniceWriter
- generateHumanReadableByteCountString(long) - Static method in class com.linkedin.venice.utils.ByteUtils
-
Convert bytes to "Human-readable" output.
- generateInput(int, boolean, int, AvroSerializer) - Static method in class com.linkedin.venice.utils.TestUtils
- generateMessageId() - Static method in class com.linkedin.venice.status.StatusMessage
- generateMetadataMap(Optional<Long>, Optional<Long>, Optional<Long>, Optional<Long>) - Static method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
- generateMetadataSchema(String) - Method in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
- generateMetadataSchema(String, int) - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
- generateMetadataSchema(Schema) - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
-
Generate the latest replication metadata schema.
- generateMetadataSchema(Schema) - Method in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
- generateMetadataSchema(Schema, int) - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
- generateMetadataSchemaFromRecord(Schema, String) - Method in class com.linkedin.venice.schema.rmd.v1.RmdSchemaGeneratorV1
- generatePartialUpdateRecordFromInput - Variable in class com.linkedin.venice.hadoop.PushJobSetting
- generatePubSubClientId(PubSubClientType, String, String) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
-
Generates a standardized and unique client ID for PubSub clients.
- generateRecordLevelTimestampMetadata(Schema, Long) - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
-
Generate an RMD payload with contains only a record level timestamp for a given metadata schema
- generateRePushId(String) - Static method in interface com.linkedin.venice.meta.Version
- generateRequestId(HttpMethod, String, long, long) - Static method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
- generateSchemaWithNamespace(String, String) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
-
Generate a new schema based on the provided schema string with the namespace specified by .
- generateSupersetSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
- generateSupersetSchema(Schema, Schema) - Method in interface com.linkedin.venice.controller.supersetschema.SupersetSchemaGenerator
-
Generate the superset schema based on two schemas.
- generateSupersetSchema(Schema, Schema) - Method in class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
- generateSupersetSchema(Schema, Schema) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
-
Generate super-set schema of two Schemas.
- generateSupersetSchemaFromAllValueSchemas(Collection<SchemaEntry>) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
- generateSupersetSchemaFromSchemas(Collection<SchemaEntry>) - Method in class com.linkedin.venice.controller.supersetschema.DefaultSupersetSchemaGenerator
- generateSupersetSchemaFromSchemas(Collection<SchemaEntry>) - Method in interface com.linkedin.venice.controller.supersetschema.SupersetSchemaGenerator
-
Function to generate a superset based on all the input schemas.
- generateSupersetSchemaFromSchemas(Collection<SchemaEntry>) - Method in class com.linkedin.venice.controller.supersetschema.SupersetSchemaGeneratorWithCustomProp
- generateSystemStoreAclBinding(AclBinding) - Method in enum class com.linkedin.venice.common.VeniceSystemStoreType
-
Generate the corresponding AclBinding for a given Venice system store type based on the corresponding Venice store's Read acl.
- generateTTLRePushId(String) - Static method in interface com.linkedin.venice.meta.Version
- GenericChunkingAdapter<V extends org.apache.avro.generic.GenericRecord> - Class in com.linkedin.davinci.storage.chunking
-
Read compute and write compute chunking adapter
- GenericChunkingAdapter() - Constructor for class com.linkedin.davinci.storage.chunking.GenericChunkingAdapter
-
Singleton
- GenericRecordChunkingAdapter - Class in com.linkedin.davinci.storage.chunking
-
Just for the sake of casting the generic type to
GenericRecord
... - GenericRecordChunkingAdapter() - Constructor for class com.linkedin.davinci.storage.chunking.GenericRecordChunkingAdapter
-
Singleton
- get() - Method in class com.linkedin.alpini.base.concurrency.ComplexAccumulator
-
Returns the current sum.
- get() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
-
Returns the current sum.
- get() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
-
Waits if necessary for the computation to complete, and then retrieves its result.
- get() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
-
Waits if necessary for the computation to complete, and then retrieves its result.
- get() - Method in class com.linkedin.alpini.base.concurrency.Lazy
- get() - Method in class com.linkedin.alpini.base.concurrency.ThreadedAccumulator
- get() - Method in class com.linkedin.alpini.base.misc.Msg
- get() - Method in class com.linkedin.alpini.base.misc.SoftThreadLocal
-
Returns the value in the current thread's copy of this thread-local variable.
- get() - Method in interface com.linkedin.davinci.store.rocksdb.RocksDBThrottler.RocksDBSupplier
- get() - Static method in class com.linkedin.venice.fastclient.stats.ClusterRouteStats
- get() - Method in class com.linkedin.venice.spark.input.VeniceAbstractPartitionReader
- get() - Method in class com.linkedin.venice.utils.ByteArray
- get() - Method in class com.linkedin.venice.utils.concurrent.CloseableThreadLocal
-
Returns the value in the current thread's copy of this thread-local variable.
- get() - Method in class com.linkedin.venice.utils.ConcurrentRef
- get() - Method in interface com.linkedin.venice.utils.lazy.Lazy
- get() - Method in class com.linkedin.venice.utils.lazy.LazyImpl
-
Returns the object wrapped by this instance.
- get() - Method in class com.linkedin.venice.utils.lazy.LazyResettableImpl
- get() - Method in class com.linkedin.venice.utils.pools.LandFillObjectPool
- get() - Method in interface com.linkedin.venice.utils.pools.ObjectPool
- get() - Method in class com.linkedin.venice.utils.ReferenceCounted
- get() - Method in interface com.linkedin.venice.utils.VeniceCheckedSupplier
- get(byte[]) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Get a value from the partition database
- get(byte[]) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- get(byte[]) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- get(byte[]) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- get(byte[]) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- get(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
- get(byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- get(int) - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
- get(int) - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
- get(int) - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
- get(int) - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
- get(int) - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
- get(int) - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
- get(int) - Method in class com.linkedin.venice.client.store.schemas.TestKeyRecord
- get(int) - Method in class com.linkedin.venice.client.store.schemas.TestValueRecord
- get(int) - Method in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
- get(int) - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.Count
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
- get(int) - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
- get(int) - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- get(int) - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
- get(int) - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
- get(int) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
- get(int) - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
- get(int) - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
- get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
- get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
- get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
- get(int) - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
- get(int) - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
- get(int) - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
- get(int) - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
- get(int) - Method in class com.linkedin.venice.kafka.protocol.Delete
- get(int) - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
- get(int) - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
- get(int) - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
- get(int) - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
- get(int) - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
- get(int) - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
- get(int) - Method in class com.linkedin.venice.kafka.protocol.Put
- get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
- get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
- get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
- get(int) - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
- get(int) - Method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
- get(int) - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
- get(int) - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
- get(int) - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
- get(int) - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
- get(int) - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
- get(int) - Method in class com.linkedin.venice.kafka.protocol.Update
- get(int) - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
- get(int) - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
- get(int) - Method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
- get(int) - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
- get(int) - Method in class com.linkedin.venice.metadata.response.VersionProperties
- get(int) - Method in class com.linkedin.venice.participant.protocol.KillPushJob
- get(int) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
- get(int) - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
- get(int) - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
- get(int) - Method in class com.linkedin.venice.pushstatus.PushStatusKey
- get(int) - Method in class com.linkedin.venice.pushstatus.PushStatusValue
- get(int) - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
- get(int) - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
- get(int) - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
- get(int) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
- get(int) - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
- get(int) - Method in class com.linkedin.venice.status.protocol.PushJobDetails
- get(int) - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
- get(int) - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
- get(int) - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
- get(int) - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
- get(int) - Method in class com.linkedin.venice.storage.protocol.ChunkId
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
- get(int) - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
- get(int) - Method in class com.linkedin.venice.utils.SparseConcurrentList
- get(int) - Method in class com.linkedin.venice.utils.SparseConcurrentListWithOffset
- get(int, byte[]) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- get(int, byte[]) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- get(int, byte[]) - Method in interface com.linkedin.davinci.store.StorageEngine
- get(int, byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- get(int, byte[], ByteBuffer) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- get(int, byte[], ByteBuffer) - Method in interface com.linkedin.davinci.store.StorageEngine
- get(int, int) - Method in class com.linkedin.venice.utils.collections.BiIntKeyCache
- get(int, ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- get(int, ByteBuffer) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- get(int, ByteBuffer) - Method in interface com.linkedin.davinci.store.StorageEngine
- get(long) - Static method in class com.linkedin.venice.unit.matchers.LongEqualOrGreaterThanMatcher
- get(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
- get(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
-
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
- get(long, TimeUnit) - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
-
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
- get(long, TimeUnit) - Method in class com.linkedin.venice.client.store.AppTimeOutTrackingCompletableFuture
- get(long, TimeUnit) - Method in class com.linkedin.venice.client.store.streaming.VeniceResponseCompletableFuture
- get(MetricNames) - Method in class com.linkedin.alpini.base.misc.Metrics
- get(StorageEngine, int, byte[], boolean, ReadResponseStats) - Static method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
- get(StorageEngine, int, byte[], ByteBuffer, T, BinaryDecoder, boolean, ReadResponseStats, int, StoreDeserializerCache<T>, VeniceCompressor) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
- get(StorageEngine, int, ByteBuffer, boolean, ReadResponseStats) - Static method in class com.linkedin.davinci.storage.chunking.BatchGetChunkingAdapter
- get(StorageEngine, int, ByteBuffer, boolean, T, BinaryDecoder, ReadResponseStats, int, StoreDeserializerCache<T>, VeniceCompressor, ChunkedValueManifestContainer) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
- get(GetRequestContext<K>, K) - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- get(GetRequestContext<K>, K) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- get(GetRequestContext<K>, K) - Method in class com.linkedin.venice.fastclient.DualReadAvroGenericStoreClient
-
TODO both super.get(key) and super.get(ctx,key) fetches non map for vsonClient for the first request.
- get(GetRequestContext<K>, K) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
- get(GetRequestContext<K>, K) - Method in class com.linkedin.venice.fastclient.LoadControlledAvroGenericStoreClient
- get(GetRequestContext<K>, K) - Method in class com.linkedin.venice.fastclient.RetriableAvroGenericStoreClient
-
TODO: Limit the retry volume: Even though retry for a single request is being scheduled at max twice (once via scheduler (LONG_TAIL_RETRY) and once instant (ERROR_RETRY) if originalRequestFuture fails), there is no way to control the total allowed retry per node.
- get(GetRequestContext<K>, K) - Method in class com.linkedin.venice.fastclient.StatsAvroGenericStoreClient
- get(VeniceClientRequest) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceBlockingStub
- get(VeniceClientRequest) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceFutureStub
- get(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.listener.grpc.VeniceReadServiceImpl
- get(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in interface com.linkedin.venice.protocols.VeniceReadServiceGrpc.AsyncService
- get(VeniceClientRequest, StreamObserver<VeniceServerResponse>) - Method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc.VeniceReadServiceStub
- get(MetricsRepository, String, String) - Method in interface com.linkedin.venice.stats.StatsSupplier
-
Legacy function, for implementations that do not use total stats in their constructor.
- get(MetricsRepository, String, String, T) - Method in interface com.linkedin.venice.stats.StatsSupplier
-
This is the function that gets called by
AbstractVeniceAggStats
, and concrete classes can optionally implement it in order to be provided with the total stats instance. - get(CharSequence) - Method in interface com.linkedin.alpini.base.misc.Headers
- get(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- get(CharSequence) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
- get(CharSequence, String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- get(Object) - Method in class com.linkedin.davinci.utils.IndexedHashMap
-
Returns the value to which the specified key is mapped, or
null
if this map contains no mapping for the key. - get(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- get(String) - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
- get(String) - Method in class com.linkedin.venice.client.store.transport.TransportClient
- get(String) - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
- get(String) - Method in interface com.linkedin.venice.pubsub.manager.TopicManagerContext.PubSubPropertiesSupplier
- get(String, int, int, BlobTransferUtils.BlobTransferTableFormat) - Method in interface com.linkedin.davinci.blobtransfer.BlobTransferManager
-
Get the blobs for the given storeName and partition
- get(String, int, int, BlobTransferUtils.BlobTransferTableFormat) - Method in class com.linkedin.davinci.blobtransfer.NettyP2PBlobTransferManager
- get(String, String, int, int, BlobTransferUtils.BlobTransferTableFormat) - Method in class com.linkedin.davinci.blobtransfer.client.NettyFileTransferClient
- get(String, Supplier<T>, Consumer<T>) - Method in class com.linkedin.venice.utils.SharedObjectFactory
-
Get a shared object that has the specified .
- get(String, Map<String, String>) - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
- get(String, Map<String, String>) - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
- get(String, Map<String, String>) - Method in class com.linkedin.venice.client.store.transport.TransportClient
- get(String, Map<String, String>) - Method in class com.linkedin.venice.fastclient.transport.GrpcTransportClient
- get(String, Map<String, String>) - Method in class com.linkedin.venice.fastclient.transport.R2TransportClient
- get(ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
- get(ByteBuffer) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- get(ByteBuffer) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- get(ByteBuffer) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- get(ByteBuffer) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- get(Executor, ClientConfig) - Method in enum class com.linkedin.venice.client.store.deserialization.BatchDeserializerType
- get(K) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- get(K) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- get(K) - Method in class com.linkedin.davinci.client.StatsAvroGenericDaVinciClient
- get(K) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Get a Value from the partition database
- get(K) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- get(K) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
- get(K) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
- get(K) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- get(K) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- get(K) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- get(K) - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
-
Lookup the value by given key, and get(key).get() will return null if it doesn't exist.
- get(K) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
- get(K) - Method in class com.linkedin.venice.client.store.RetriableStoreClient
-
Adding retry logic on router error as this method returning the completion stage value.
- get(K) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
- get(K) - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
- get(K, Version, AsyncCacheLoader<K, V>) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
- get(K, Function<K, V>) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
- get(K, Function<K, V>) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
-
Returns the value associated with the
key
in this cache, obtaining that value from themappingFunction
when a value is not already associated to the key. - get(K, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- get(K, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- get(K, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
- get(K, V) - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- get(K, V) - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- get(K, V) - Method in class com.linkedin.davinci.client.StatsAvroGenericDaVinciClient
- get(K, V) - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
-
Similar to
AvroGenericStoreClient.get(Object)
except that it allows passing in a instance, to minimize GC. - GET - Enum constant in enum class com.linkedin.venice.authorization.Method
- GET - Enum constant in enum class com.linkedin.venice.HttpMethod
- GET_ACL - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_ADMIN_OPERATION_VERSION_FROM_CONTROLLERS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_ADMIN_TOPIC_METADATA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_ALL - Enum constant in enum class com.linkedin.venice.authorization.Method
- GET_ALL_MIGRATION_PUSH_STRATEGIES - Enum constant in enum class com.linkedin.venice.Command
- GET_ALL_MIGRATION_PUSH_STRATEGIES - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_ALL_REPLICATION_METADATA_SCHEMAS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_ALL_VALUE_AND_DERIVED_SCHEMA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_ALL_VALUE_SCHEMA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_CLUSTER_STORAGE_PERSONAS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_DEAD_STORES - Enum constant in enum class com.linkedin.venice.Command
- GET_DEAD_STORES - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_DELETABLE_STORE_TOPICS - Enum constant in enum class com.linkedin.venice.Command
- GET_DELETABLE_STORE_TOPICS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_EXECUTION - Enum constant in enum class com.linkedin.venice.Command
- GET_HEARTBEAT_TIMESTAMP_FROM_SYSTEM_STORE - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_INUSE_SCHEMA_IDS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_KAFKA_TOPIC_CONFIGS - Enum constant in enum class com.linkedin.venice.Command
- GET_KAFKA_TOPIC_CONFIGS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_KEY_SCHEMA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_LOADED_STORE_USER_PARTITION_MAPPING - Enum constant in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionAction
- GET_LOCAL_ADMIN_OPERATION_PROTOCOL_VERSION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_MIGRATION_PUSH_STRATEGY - Enum constant in enum class com.linkedin.venice.Command
- GET_ONGOING_INCREMENTAL_PUSH_VERSIONS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_PARTITION_ID - Enum constant in enum class com.linkedin.venice.Command
- GET_REGION_PUSH_DETAILS - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_REPUSH_INFO - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_ROUTERS_CLUSTER_CONFIG - Enum constant in enum class com.linkedin.venice.Command
- GET_ROUTERS_CLUSTER_CONFIG - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_STALE_STORES_IN_CLUSTER - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_STORAGE_PERSONA - Enum constant in enum class com.linkedin.venice.Command
- GET_STORAGE_PERSONA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_STORAGE_PERSONA_ASSOCIATED_WITH_STORE - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_STORAGE_PERSONA_FOR_STORE - Enum constant in enum class com.linkedin.venice.Command
- GET_STORE_ACL - Enum constant in enum class com.linkedin.venice.Command
- GET_STORE_LARGEST_USED_VERSION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_STORES_FOR_COMPACTION - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_STORES_IN_CLUSTER - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_VALUE_OR_DERIVED_SCHEMA_ID - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_VALUE_SCHEMA - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- GET_VALUE_SCHEMA_ID - Enum constant in enum class com.linkedin.venice.controllerapi.ControllerRoute
- getAaWCIngestionStorageLookupThreadPool() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getAaWCIngestionStorageLookupThreadPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAaWCLeaderQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAAWCWorkloadParallelProcessingThreadPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAAWCWorkLoadProcessingThreadPool() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getAbbreviatedNameValuePairs() - Method in class com.linkedin.venice.controllerapi.QueryParams
- getAccessControlled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'accessControlled' field.
- getAccessControlled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getAccessControlled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'accessControlled' field.
- getAccessControlled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'accessControlled' field.
- getAccessControlledResources() - Method in interface com.linkedin.venice.acl.DynamicAccessController
-
Get a list of currently being access-controlled resources.
- getAccessControlledResources() - Method in class com.linkedin.venice.acl.NoOpDynamicAccessController
- getAccessController() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getAccessController() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getAccessibleField(Class<?>, String) - Static method in class com.linkedin.alpini.base.misc.ClassUtil
- getAccessibleField(Field) - Static method in class com.linkedin.alpini.base.misc.ClassUtil
- getAccessPermission() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional string accessPermission = 6;
- getAccessPermission() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
optional string accessPermission = 6;
- getAccessPermission() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
optional string accessPermission = 6;
- getAccessPermissionBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional string accessPermission = 6;
- getAccessPermissionBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
optional string accessPermission = 6;
- getAccessPermissionBytes() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
optional string accessPermission = 6;
- getAccessPermissions() - Method in class com.linkedin.venice.controllerapi.AclResponse
- getAccessPermissions() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
-
string accessPermissions = 2;
- getAccessPermissions() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
-
string accessPermissions = 2;
- getAccessPermissions() - Method in interface com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponseOrBuilder
-
string accessPermissions = 2;
- getAccessPermissions() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
-
string accessPermissions = 3;
- getAccessPermissions() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
-
string accessPermissions = 3;
- getAccessPermissions() - Method in interface com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequestOrBuilder
-
string accessPermissions = 3;
- getAccessPermissionsBytes() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
-
string accessPermissions = 2;
- getAccessPermissionsBytes() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
-
string accessPermissions = 2;
- getAccessPermissionsBytes() - Method in interface com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponseOrBuilder
-
string accessPermissions = 2;
- getAccessPermissionsBytes() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
-
string accessPermissions = 3;
- getAccessPermissionsBytes() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
-
string accessPermissions = 3;
- getAccessPermissionsBytes() - Method in interface com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequestOrBuilder
-
string accessPermissions = 3;
- getAceEntries() - Method in class com.linkedin.venice.authorization.AclBinding
-
Returns an unmodifiable list of existing ace entries.
- getAclForStore(Admin, StoreRequestHandler) - Method in class com.linkedin.venice.controller.server.CreateStore
- getAclForStore(GetAclForStoreGrpcRequest) - Method in class com.linkedin.venice.controller.server.StoreRequestHandler
- getAclForStore(GetAclForStoreGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceBlockingStub
- getAclForStore(GetAclForStoreGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceFutureStub
- getAclForStore(GetAclForStoreGrpcRequest, StreamObserver<GetAclForStoreGrpcResponse>) - Method in class com.linkedin.venice.controller.grpc.server.StoreGrpcServiceImpl
- getAclForStore(GetAclForStoreGrpcRequest, StreamObserver<GetAclForStoreGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.AsyncService
- getAclForStore(GetAclForStoreGrpcRequest, StreamObserver<GetAclForStoreGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc.StoreGrpcServiceStub
- getAclForStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAclForStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Fetch the current set of ACL provisioned for a venice store and its associated kafka topic.
- getAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAclForStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- GetAclForStoreGrpcRequest - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- GetAclForStoreGrpcRequest.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- GetAclForStoreGrpcRequestOrBuilder - Interface in com.linkedin.venice.protocols.controller
- GetAclForStoreGrpcResponse - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- GetAclForStoreGrpcResponse.Builder - Class in com.linkedin.venice.protocols.controller
-
Protobuf type
com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- GetAclForStoreGrpcResponseOrBuilder - Interface in com.linkedin.venice.protocols.controller
- getAclHandler(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- getAclInMemoryCacheTTLMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAclInMemoryCacheTTLMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getActiveActiveRealTimeSourceKafkaURLs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getActiveActiveReplicationCheck(Admin, Store, String, String, boolean) - Method in class com.linkedin.venice.controller.server.CreateVersion
- getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'activeActiveReplicationEnabled' field.
- getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'activeActiveReplicationEnabled' field.
- getActiveActiveReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'activeActiveReplicationEnabled' field.
- getActiveElementTimestamps() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- getActiveStoreVersions() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
-
Helper methods for unit testing
- getActiveStreams() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getActiveStreams() - Method in interface com.linkedin.alpini.router.impl.Router
- getActiveStreamsCount() - Method in class io.netty.handler.codec.http2.ActiveStreamsCountHandler
-
Return the current active streams.
- getActiveStreamsCountHandler() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- getActiveStreamsCountHandler() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getAdapterSerializer() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAdaptiveThrottlerMultiGetLatencyThreshold() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAdaptiveThrottlerReadComputeLatencyThreshold() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAdaptiveThrottlerSignalIdleThreshold() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAdaptiveThrottlerSingleGetLatencyThreshold() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getAdmin() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getAdmin() - Method in class com.linkedin.venice.controller.server.VeniceControllerRequestHandler
- getAdmin(String, Config) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
- getAdminAdapterFactory() - Method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- getAdminClientName() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterContext
- getAdminCommandExecution(long) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
-
int64 adminCommandExecutionId = 2;
- getAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
-
int64 adminCommandExecutionId = 2;
- getAdminCommandExecutionId() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequestOrBuilder
-
int64 adminCommandExecutionId = 2;
- getAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
int64 adminCommandExecutionId = 2;
- getAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
int64 adminCommandExecutionId = 2;
- getAdminCommandExecutionId() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
int64 adminCommandExecutionId = 2;
- getAdminCommandExecutionStatus(AdminCommandExecutionStatusGrpcRequest) - Method in class com.linkedin.venice.controller.server.ClusterAdminOpsRequestHandler
- getAdminCommandExecutionStatus(AdminCommandExecutionStatusGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceBlockingStub
-
AdminCommandExecution
- getAdminCommandExecutionStatus(AdminCommandExecutionStatusGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceFutureStub
-
AdminCommandExecution
- getAdminCommandExecutionStatus(AdminCommandExecutionStatusGrpcRequest, StreamObserver<AdminCommandExecutionStatusGrpcResponse>) - Method in class com.linkedin.venice.controller.grpc.server.ClusterAdminOpsGrpcServiceImpl
- getAdminCommandExecutionStatus(AdminCommandExecutionStatusGrpcRequest, StreamObserver<AdminCommandExecutionStatusGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.AsyncService
-
AdminCommandExecution
- getAdminCommandExecutionStatus(AdminCommandExecutionStatusGrpcRequest, StreamObserver<AdminCommandExecutionStatusGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceStub
-
AdminCommandExecution
- getAdminCommandExecutionTracker(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get the tracker used to track the execution of the admin command for the given cluster.
- getAdminCommandExecutionTracker(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAdminCommandExecutionTracker(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getAdminConsumerService(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAdminConsumerServiceByCluster(String) - Method in class com.linkedin.venice.controller.VeniceControllerService
-
This method is for testing.
- getAdminConsumptionCycleTimeoutMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminConsumptionMaxWorkerThreadPoolSize() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminGrpcPort() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminGrpcPort() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getAdminHostname() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminHostname() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getAdminOperation() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
- getAdminOperationProtocolVersion() - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
- getAdminOperationProtocolVersion() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 adminOperationProtocolVersion = 6;
- getAdminOperationProtocolVersion() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
optional int64 adminOperationProtocolVersion = 6;
- getAdminOperationProtocolVersion() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
optional int64 adminOperationProtocolVersion = 6;
- getAdminOperationProtocolVersion() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
-
int64 adminOperationProtocolVersion = 2;
- getAdminOperationProtocolVersion() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
-
int64 adminOperationProtocolVersion = 2;
- getAdminOperationProtocolVersion() - Method in interface com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequestOrBuilder
-
int64 adminOperationProtocolVersion = 2;
- getAdminOperationProtocolVersion(Map<String, Long>) - Static method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
- getAdminOperationProtocolVersionFromControllers(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAdminOperationVersionFromControllers(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
-
Get all admin operation protocol versions of the given cluster from controllers (leader + standby).
- getAdminOperationVersionFromControllers(String) - Method in interface com.linkedin.venice.controller.Admin
- getAdminOperationVersionFromControllers(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Get the admin operation protocol versions from all controllers for specific cluster.
- getAdminOperationVersionFromControllers(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getAdminPort() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminPort() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getAdminProperties() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
- getAdminSecureGrpcPort() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminSecureGrpcPort() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getAdminSecurePort() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminSecurePort() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getAdminTopicMetadata(Admin, ClusterAdminOpsRequestHandler) - Method in class com.linkedin.venice.controller.server.AdminTopicMetadataRoutes
- getAdminTopicMetadata(AdminTopicMetadataGrpcRequest) - Method in class com.linkedin.venice.controller.server.ClusterAdminOpsRequestHandler
- getAdminTopicMetadata(AdminTopicMetadataGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceBlockingStub
-
AdminTopicMetadata
- getAdminTopicMetadata(AdminTopicMetadataGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceFutureStub
-
AdminTopicMetadata
- getAdminTopicMetadata(AdminTopicMetadataGrpcRequest, StreamObserver<AdminTopicMetadataGrpcResponse>) - Method in class com.linkedin.venice.controller.grpc.server.ClusterAdminOpsGrpcServiceImpl
- getAdminTopicMetadata(AdminTopicMetadataGrpcRequest, StreamObserver<AdminTopicMetadataGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.AsyncService
-
AdminTopicMetadata
- getAdminTopicMetadata(AdminTopicMetadataGrpcRequest, StreamObserver<AdminTopicMetadataGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceStub
-
AdminTopicMetadata
- getAdminTopicMetadata(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
- getAdminTopicMetadata(String, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
- getAdminTopicMetadata(String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAdminTopicMetadata(String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Get AdminTopicMetadata from parent controller
- getAdminTopicMetadata(Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAdminTopicReplicationFactor() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAdminTopicSourceRegion() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAge() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getAge() - Method in interface com.linkedin.venice.meta.Version
- getAge() - Method in class com.linkedin.venice.meta.VersionImpl
- getAggKafkaConsumerService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getAggregatedHealthStatus(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
- getAggregatedHealthStatus(String, List<String>, List<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAggregatedHealthStatus(String, List<String>, List<String>, boolean) - Method in interface com.linkedin.venice.controller.Admin
- getAggregatedHealthStatus(String, List<String>, List<String>, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAggregatedHealthStatus(String, List<String>, List<String>, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getAggregatedMetrics() - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
-
Gets the value of the 'aggregatedMetrics' field.
- getAggregateRealTimeSourceRegion() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getAggregateRealTimeTopicSource(String) - Method in interface com.linkedin.venice.controller.Admin
-
Return the source Kafka boostrap server url for aggregate real-time topic updates
- getAggregateRealTimeTopicSource(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAggregateRealTimeTopicSource(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getAggregates() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'aggregates' field.
- getAggregates() - Method in class com.linkedin.venice.kafka.validation.Segment
- getAggStatistics() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getAggVersionedBlobTransferStats() - Method in interface com.linkedin.davinci.blobtransfer.BlobTransferManager
-
Get the blob transfer stats
- getAggVersionedBlobTransferStats() - Method in class com.linkedin.davinci.blobtransfer.NettyP2PBlobTransferManager
-
Get the blob transfer stats
- getAggVersionedIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getAggVersionedIngestionStats() - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
-
Get AggVersionedStorageIngestionStats
- getAll(CharSequence) - Method in interface com.linkedin.alpini.base.misc.Headers
- getAll(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getAll(CharSequence) - Method in class com.linkedin.alpini.netty4.misc.BasicHeaders
- getAll(Iterable<K>, Version, Function<Iterable<K>, Map<K, V>>, AsyncCacheLoader<K, V>) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
- getAll(Iterable<K>, Function<Iterable<K>, Map<K, V>>) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
- getAll(Iterable<K>, Function<Iterable<K>, Map<K, V>>) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
-
Returns a map of the values associated with the
keys
, creating or retrieving those values if necessary. - getAll(String) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getAllDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getAllEnumString() - Static method in enum class com.linkedin.venice.migration.MigrationPushStrategy
- getAllInstances(String, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
-
This function is mainly used in VeniceVersionFinder#anyOfflinePartitions() when there is no online replica for a specific partition, and it calls this function to get the partition assignment info for error msg.
- getAllInstances(String, int) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
-
Query instances that belong to given kafka topic and partition.
- getAllInstancesByExecutionStatus() - Method in class com.linkedin.venice.meta.Partition
- getAllInstancesByHelixState() - Method in class com.linkedin.venice.meta.Partition
- getAllInstancesSet() - Method in class com.linkedin.venice.meta.Partition
- getAllLiveInstanceControllers() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Get all live instance controllers from ZK /LIVEINSTANCES
- getAllLiveInstances() - Method in class com.linkedin.venice.helix.HelixLiveInstanceMonitor
- getAllLiveInstances() - Method in interface com.linkedin.venice.meta.LiveInstanceMonitor
- getAllLocalStorageEngines() - Method in class com.linkedin.davinci.storage.StorageEngineRepository
- getAllMetricPrefixes(String) - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
- getAllMetrics() - Method in class com.linkedin.venice.tehuti.MockTehutiReporter
- getAllMigrationPushStrategies(Admin) - Method in class com.linkedin.venice.controller.server.MigrationRoutes
-
No ACL check; any user is allowed to check migration strategy.
- getAllModels() - Method in class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
- getAllowlist(String) - Method in interface com.linkedin.venice.controller.Admin
- getAllowlist(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAllowlist(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getAllowList(String) - Method in interface com.linkedin.venice.helix.AllowlistAccessor
-
Get all helix nodeIds in the allowlist of the given cluster from ZK.
- getAllowList(String) - Method in class com.linkedin.venice.helix.ZkAllowlistAccessor
-
Get all helix nodeIds in the allowlist of the given cluster from ZK.
- getAllPartitionNames(String) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
- getAllPartitionNames(String) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
- getAllPartitionNames(String) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
- getAllPartitions() - Method in class com.linkedin.venice.meta.PartitionAssignment
- getAllPersonas() - Method in class com.linkedin.venice.helix.StoragePersonaRepository
- getAllPersonasFromZk() - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
- getAllPresent(Iterable<K>) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
- getAllPresent(Iterable<K>) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
-
Returns a map of the values associated with the
keys
in this cache. - getAllPushNames(String) - Method in class com.linkedin.venice.helix.ParentHelixOfflinePushAccessor
- getAllPushStrategies() - Method in class com.linkedin.venice.controller.migration.MigrationPushStrategyZKAccessor
-
The reason to return the push strategy for all the stores: 1.
- getAllRealTimeTopicNames(Store) - Static method in class com.linkedin.venice.utils.Utils
- getAllReplicaStatus(HelixPartitionState, String) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
- getAllReplicaStatus(String) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
- getAllReplicationMetadataSchemas(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
- getAllReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAllReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getAllSchemasFromResources(AvroProtocolDefinition) - Static method in class com.linkedin.venice.utils.Utils
- getAllStorePushStrategyForMigration() - Method in interface com.linkedin.venice.controller.Admin
- getAllStorePushStrategyForMigration() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Unsupported operation in the child controller.
- getAllStorePushStrategyForMigration() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getAllStores() - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getAllStores() - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
-
This method will only return all the subscribed Venice stores and not include the view stores for the following reasons: 1.
- getAllStores() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getAllStores() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
-
So far, this function will return the regular Venice stores + the corresponding meta system store.
- getAllStores() - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
- getAllStores() - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
- getAllStores() - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
-
Get all stores in the current repository
- getAllStores(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
-
No ACL check; any user can try to list stores.
- getAllStores(String) - Method in interface com.linkedin.venice.controller.Admin
- getAllStores(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAllStores(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getAllStoresStatuses(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
-
No ACL check; any user can try to list store statuses.
- getAllStoreStatuses(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get the statuses of all stores.
- getAllStoreStatuses(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getAllStoreStatuses(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getAllTopicRetentions() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
-
Retrieves the retention settings for all Kafka topics.
- getAllTopicRetentions() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Retrieves the retention settings for all PubSub topics.
- getAllTopicRetentions() - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Get retention time for all topics in the pubsub cluster.
- getAllTopicRetentions() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- getAllValueAndDerivedSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
- getAllValueAndDerivedSchema(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAllValueSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
-
Route to handle retrieving all value schema for a given store.
- getAllValueSchema(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getAllValueSchemas() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
-
Returns all value schemas of the store.
- getAllValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getAllValueSchemasWithId() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
- getAllValueSchemasWithId() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
-
Returns all value schemas of the store as a map with schema id as the key.
- getAllVeniceStoreTopicsRetentions(Map<PubSubTopic, Long>) - Static method in class com.linkedin.venice.controller.kafka.TopicCleanupService
- getAllVersionNumbers() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
-
return a deep copy of all version numbers
- getAlwaysBootstrapFromVersionTopic() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
- getAlwaysBootstrapFromVersionTopic() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerConfig
- getAmortizedRefillPerSecond() - Method in class com.linkedin.venice.throttle.TokenBucket
- getAmplificationFactor() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
-
Gets the value of the 'amplificationFactor' field.
- getAmplificationFactor() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getAmplificationFactor() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getAmplificationFactor() - Method in interface com.linkedin.venice.meta.PartitionerConfig
- getAmplificationFactor() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
- getAmplificationFactor() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
-
Gets the value of the 'amplificationFactor' field.
- getAmplificationFactor() - Method in class com.linkedin.venice.metadata.response.VersionProperties
-
Gets the value of the 'amplificationFactor' field.
- getAmplificationFactor() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
-
Gets the value of the 'amplificationFactor' field.
- getAndCacheSchemaData(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getAndIncrementSequenceNumber() - Method in class com.linkedin.venice.kafka.validation.Segment
-
N.B.
- getAndStartAvroClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getAndStartAvroGenericStoreClient(String) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
- getAndStartAvroGenericStoreClient(String) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
- getAndStartAvroGenericStoreClient(String, VeniceStoreClientFactory.ClientConfigUpdater) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
- getAndStartAvroGenericStoreClient(String, VeniceStoreClientFactory.ClientConfigUpdater) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
-
create a generic client along with customized client configs.
- getAndStartAvroSpecificStoreClient(String, Class<V>) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
- getAndStartAvroSpecificStoreClient(String, Class<V>) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
- getAndStartAvroSpecificStoreClient(String, Class<V>, VeniceStoreClientFactory.ClientConfigUpdater) - Method in class com.linkedin.venice.client.factory.CachingVeniceStoreClientFactory
- getAndStartAvroSpecificStoreClient(String, Class<V>, VeniceStoreClientFactory.ClientConfigUpdater) - Method in interface com.linkedin.venice.client.factory.VeniceStoreClientFactory
- getAndStartGenericAvroClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getAndStartGenericAvroClient(String, DaVinciConfig) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getAndStartGenericAvroClient(String, DaVinciConfig) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getAndStartGenericAvroClient(String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getAndStartGenericAvroClient(String, String, DaVinciConfig) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getAndStartGenericAvroClient(String, String, DaVinciConfig) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getAndStartGenericStoreClient(ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
- getAndStartGenericStoreClient(StoreMetadata, ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
-
TODO: once we decide to completely remove the helix based implementation, we won't need to pass the param: in these factory methods.
- getAndStartSpecificAvroClient(ClientConfig<V>) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getAndStartSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getAndStartSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getAndStartSpecificAvroClient(String, String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getAndStartSpecificAvroClient(String, String, DaVinciConfig, Class<V>) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getAndStartSpecificStoreClient(ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
- getAndStartSpecificStoreClient(StoreMetadata, ClientConfig) - Static method in class com.linkedin.venice.fastclient.factory.ClientFactory
- getAndUpdateLeaderCompletedState(KafkaKey, KafkaMessageEnvelope, ControlMessage, PubSubMessageHeaders, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
-
HeartBeat SOS messages carry the leader completion state in the header.
- getAnnotatedDerivedSchemaEntry(DerivedSchemaEntry) - Static method in class com.linkedin.davinci.schema.SchemaUtils
-
Create a new
DerivedSchemaEntry
for partial update schema annotation. - getAnnotatedRmdSchemaEntry(RmdSchemaEntry) - Static method in class com.linkedin.davinci.schema.SchemaUtils
- getAnnotatedValueSchemaEntry(SchemaEntry) - Static method in class com.linkedin.davinci.schema.SchemaUtils
-
Create a new
SchemaEntry
for value schema annotation. - getAnnouncingTargetID() - Method in class com.linkedin.venice.d2.D2Server
-
Get a ID string consists of the attributes that uniquely define the announcing target, which are: 1) doNotStart 2) zkHosts 3) zk announcers (clusterName + nodeUri) -- Note that there should be exactly one announcer according to the current usage in
D2ServerFactory
. - getAny() - Method in class com.linkedin.venice.meta.StoreDataAudit
- getApplyTargetVersionFilterForIncPush() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'applyTargetVersionFilterForIncPush' field.
- getApplyTargetVersionFilterForIncPush() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'applyTargetVersionFilterForIncPush' field.
- getApproximateMemoryUsageByType(Set<Cache>) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getArgName() - Method in enum class com.linkedin.venice.Arg
- getAsMap() - Method in class com.linkedin.venice.utils.VeniceProperties
- getAssignedNumberOfPartitions() - Method in class com.linkedin.venice.meta.PartitionAssignment
- getAssignedResources() - Method in class com.linkedin.venice.helix.ResourceAssignment
- getAssignment() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- getAssignment() - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
-
Retrieves the set of PubSub topic-partitions currently assigned to the consumer.
- getAssignment() - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
- getAttempts() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getAttemptsCount() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getAttributes() - Method in class com.linkedin.venice.stats.metrics.MetricEntityStateBase
-
visibility for testing
- getAttributes(E1, E2, E3) - Method in class com.linkedin.venice.stats.metrics.MetricEntityStateThreeEnums
-
Manages the nested EnumMap structure for lazy initialization of Attributes.
- getAttributesEnumMap() - Method in class com.linkedin.venice.stats.metrics.MetricEntityStateOneEnum
-
visible for testing
- getAttributesEnumMap() - Method in class com.linkedin.venice.stats.metrics.MetricEntityStateThreeEnums
-
visible for testing
- getAttributesEnumMap() - Method in class com.linkedin.venice.stats.metrics.MetricEntityStateTwoEnums
-
visible for testing
- getAuditMap() - Method in class com.linkedin.venice.controllerapi.ClusterStaleDataAuditResponse
- getAuthorizerService() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getAutoSchemaRegisterPushJobEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getAvailablePermits() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Returns the number of available permits for handshakes.
- getAvg() - Method in class com.linkedin.davinci.stats.WritePathLatencySensor
- getAvg(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
- getAvroChunkingAdapter() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- getAvroGenericDeserializer(Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
-
This function is assuming that both writer and reader are using the same schema.
- getAvroGenericDeserializer(Schema, Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
- getAvroGenericSerializer(Schema) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
- getAvroGenericSerializer(Schema, boolean) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
- getAvroKey(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
-
Return an Avro output key
- getAvroKey(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
- getAvroKey(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
- getAvroKey(BytesWritable, BytesWritable) - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
- getAvroSpecificDeserializer(Class<V>) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
-
This function is assuming that both writer and reader are using the same schema defined in .
- getAvroSpecificDeserializer(Schema, Class<V>) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
- getAvroSpecificDeserializerInternal(Schema, Class<V>, Function<SerializerDeserializerFactory.SchemaPairAndClassContainer, AvroSpecificDeserializer<? extends SpecificRecord>>) - Static method in class com.linkedin.venice.serializer.SerializerDeserializerFactory
- getAvroValue(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
-
return an Avro output value
- getAvroValue(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
- getAvroValue(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
- getAvroValue(BytesWritable, BytesWritable) - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
- getBackend() - Static method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- getBackendConfig() - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getBackupStrategy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'backupStrategy' field.
- getBackupStrategy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getBackupStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getBackupStrategy() - Method in interface com.linkedin.venice.meta.Store
- getBackupStrategy() - Method in class com.linkedin.venice.meta.StoreInfo
- getBackupStrategy() - Method in class com.linkedin.venice.meta.SystemStore
- getBackupStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'backupStrategy' field.
- getBackupStrategy() - Method in class com.linkedin.venice.meta.ZKStore
- getBackupStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'backupStrategy' field.
- getBackupVersion() - Method in class com.linkedin.venice.stats.ServerReadQuotaUsageStats
- getBackupVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getBackupVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getBackupVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getBackupVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getBackupVersionCleanupSleepMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getBackupVersionCleanupSleepMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getBackupVersionDefaultRetentionMs() - Method in interface com.linkedin.venice.controller.Admin
-
Returns default backup version retention time.
- getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getBackupVersionDefaultRetentionMs() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getBackupVersionNumber(List<Version>, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Get backup version number, the largest online version number that is less than the current version number
- getBackupVersionRetentionMs() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'backupVersionRetentionMs' field.
- getBackupVersionRetentionMs() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getBackupVersionRetentionMs() - Method in interface com.linkedin.venice.meta.Store
- getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.StoreInfo
- getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.SystemStore
- getBackupVersionRetentionMs() - Method in class com.linkedin.venice.meta.ZKStore
- getBackupVersionRetentionMs() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'backupVersionRetentionMs' field.
- getBackupVersions(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getBackupVersionsForMultiColos(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getBackupVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getBackupVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getBadMetaSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
- getBadPushStatusSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
- getBaseAttributes() - Method in class com.linkedin.davinci.consumer.stats.BasicConsumerStats
- getBaseDir() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getBatchConflictResolutionPolicy() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'batchConflictResolutionPolicy' field.
- getBatchFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getBatchFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getBatchFollowerOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchGetDeserializer(Executor) - Method in class com.linkedin.venice.client.store.ClientConfig
- getBatchGetLimit() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'batchGetLimit' field.
- getBatchGetLimit() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getBatchGetLimit() - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
- getBatchGetLimit() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getBatchGetLimit() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getBatchGetLimit() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getBatchGetLimit() - Method in interface com.linkedin.venice.meta.Store
- getBatchGetLimit() - Method in class com.linkedin.venice.meta.StoreInfo
- getBatchGetLimit() - Method in class com.linkedin.venice.meta.SystemStore
- getBatchGetLimit() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'batchGetLimit' field.
- getBatchGetLimit() - Method in class com.linkedin.venice.meta.ZKStore
- getBatchGetLimit() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'batchGetLimit' field.
- getBatchGetLimit() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'batchGetLimit' field.
- getBatchGetLimit(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getBatchGetLimit(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getBatchGetLimit(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getBatchGetLimit(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
- getBatchGetLimit(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
-
Only return zk shared system store related info, otherwise
VeniceException
will be thrown. - getBatchGetLimit(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
-
Get batch-get limit for the specified store
- getBatchGetMethod() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
- getBatchGetRouterCacheEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'batchGetRouterCacheEnabled' field.
- getBatchGetRouterCacheEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'batchGetRouterCacheEnabled' field.
- getBatchJobHeartbeatEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getBatchJobHeartbeatEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getBatchJobHeartbeatInitialBufferTime() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getBatchJobHeartbeatInitialBufferTime() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getBatchJobHeartbeatStoreCluster() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getBatchJobHeartbeatStoreCluster() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getBatchJobHeartbeatTimeout() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getBatchJobHeartbeatTimeout() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getBatchJobHeartbeatValue(BatchJobHeartbeatKey) - Method in interface com.linkedin.venice.controller.Admin
- getBatchJobHeartbeatValue(BatchJobHeartbeatKey) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getBatchJobHeartbeatValue(BatchJobHeartbeatKey) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getBatchLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getBatchLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getBatchLeaderOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchProcessingRequest() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchProcessingRequestError() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchProcessingRequestLatencySensor() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchProcessingRequestRecords() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchProcessingRequestSizeSensor() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchReplicationLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getBatchReplicationLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getBatchReplicationLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getBatchReportEOIPEnabled() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBenignLeaderOffsetRewindCount() - Method in class com.linkedin.davinci.stats.DIVStats
- getBenignLeaderProducerFailure() - Method in class com.linkedin.davinci.stats.DIVStats
- getBlobFileSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getBlobFileStartingLevel() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getBlobGarbageCollectionAgeCutOff() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getBlobGarbageCollectionForceThreshold() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getBlobReceiveMaxTimeoutInMin() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBlobReceiveTimeoutInMin() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getBlobTransferClientReadLimitBytesPerSec() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getBlobTransferClientReadLimitBytesPerSec() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBlobTransferDisabledOffsetLagThreshold() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBlobTransferEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'blobTransferEnabled' field.
- getBlobTransferEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getBlobTransferEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'blobTransferEnabled' field.
- getBlobTransferEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'blobTransferEnabled' field.
- getBlobTransferEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'blobTransferEnabled' field.
- getBlobTransferFailedNumResponses() - Method in class com.linkedin.davinci.stats.BlobTransferStats
- getBlobTransferFileReceiveThroughput() - Method in class com.linkedin.davinci.stats.BlobTransferStats
- getBlobTransferMaxTimeoutInMin() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getBlobTransferMaxTimeoutInMin() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBlobTransferPeersConnectivityFreshnessInSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBlobTransferServiceWriteLimitBytesPerSec() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getBlobTransferServiceWriteLimitBytesPerSec() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBlobTransferSuccessNumResponses() - Method in class com.linkedin.davinci.stats.BlobTransferStats
- getBlobTransferTableFormat() - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Get the current snapshot format, which is a config value.
- getBlobTransferTime() - Method in class com.linkedin.davinci.stats.BlobTransferStats
- getBlobTransferTotalNumResponses() - Method in class com.linkedin.davinci.stats.BlobTransferStats
-
All get methods to get the sensor value
- getBlockBaseFormatVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getBlockedInstanceCount() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
- getBlockingQueueType() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getBlockingReason() - Method in class com.linkedin.venice.controller.NodeRemovableResult
- getBlockingResource() - Method in class com.linkedin.venice.controller.NodeRemovableResult
- getBody() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
- getBody() - Method in class com.linkedin.venice.listener.response.BinaryResponse
- getBody() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getBody() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getBody() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- getBodyParams() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Post
- getBodyParams() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Put
- getBoolean(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getBoolean(String, boolean) - Method in class com.linkedin.venice.utils.VeniceProperties
- getBooleanWithAlternative(String, String, boolean) - Method in class com.linkedin.venice.utils.VeniceProperties
- getBootstrapFileSystemPath() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getBootstrappingChangelogConsumer(String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
- getBootstrappingChangelogConsumer(String, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
- getBootstrappingChangelogConsumer(String, String, Class<K>, Class<V>, Schema) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
-
Use this if you're using the experimental client
- getBootstrappingChangelogConsumer(String, String, Class<V>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
-
Creates a BootstrappingVeniceChangelogConsumer with consumer id.
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'bootstrapToOnlineTimeoutInHours' field.
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getBootstrapToOnlineTimeoutInHours() - Method in interface com.linkedin.venice.meta.Store
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.StoreInfo
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.SystemStore
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'bootstrapToOnlineTimeoutInHours' field.
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.meta.ZKStore
- getBootstrapToOnlineTimeoutInHours() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'bootstrapToOnlineTimeoutInHours' field.
- getBrokerAddress() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
- getBrokerAddress() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
- getBrokerAddress() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
- getBrokerAddress() - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
- getBrokerAddress() - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterConcurrentDelegator
- getBrokerAddress() - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterDelegator
- getBrokerAddress() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getBrokerAddress() - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
- getBrokerAddress() - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
- getBrokerAddress() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getBucketNameToCount(String) - Method in interface com.linkedin.venice.client.store.ComputeAggregationResponse
- getBufferReplayEnabledForHybrid() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'bufferReplayEnabledForHybrid' field.
- getBufferReplayEnabledForHybrid() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'bufferReplayEnabledForHybrid' field.
- getBufferReplayPolicy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
-
Gets the value of the 'bufferReplayPolicy' field.
- getBufferReplayPolicy() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
- getBufferReplayPolicy() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- getBufferReplayPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
-
Gets the value of the 'bufferReplayPolicy' field.
- getByIndex(int) - Method in class com.linkedin.davinci.utils.IndexedHashMap
-
O(1)
- getByIndex(int) - Method in interface com.linkedin.davinci.utils.IndexedMap
- getByIndex(int) - Method in interface com.linkedin.venice.utils.IndexedMap
- getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Populate provided callback with key-value pairs from the partition database where the keys have provided prefix.
- getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- getByKeyPrefix(byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getByKeyPrefix(int, byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- getByKeyPrefix(int, byte[], BytesStreamingCallback) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getByKeyPrefix(int, byte[], BytesStreamingCallback) - Method in interface com.linkedin.davinci.store.StorageEngine
- getByPartialKey(StorageEngine, int, byte[], T, BinaryDecoder, RecordDeserializer<GenericRecord>, boolean, int, StoreDeserializerCache<T>, VeniceCompressor, StreamingCallback<GenericRecord, GenericRecord>) - Method in class com.linkedin.davinci.storage.chunking.AbstractAvroChunkingAdapter
- getByteArraySizeByLength(int) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
- getByteRate() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- getBytes() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
- getBytesConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
- getCache() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
- getCacheConfig() - Method in class com.linkedin.davinci.client.DaVinciConfig
- getCachedRMDSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineStats
- getCachedRMDSizeInBytes() - Method in class com.linkedin.davinci.store.StorageEngineNoOpStats
- getCachedRMDSizeInBytes() - Method in interface com.linkedin.davinci.store.StorageEngineStats
- getCachedStoreSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineStats
- getCachedStoreSizeInBytes() - Method in class com.linkedin.davinci.store.StorageEngineNoOpStats
- getCachedStoreSizeInBytes() - Method in interface com.linkedin.davinci.store.StorageEngineStats
- getCachedTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Still heavy, but can be called repeatedly to amortize that cost.
- getCacheInvalidatingStoreChangeListener() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
- getCallback() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- getCallback() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
- getCallback() - Method in class com.linkedin.venice.writer.CompletableFutureCallback
- getCanonicalPath(String) - Static method in class com.linkedin.venice.utils.Utils
-
Get the full Path of the file.
- getCanonicalSchemaStr() - Method in class com.linkedin.venice.schema.SchemaEntry
- getCapacity() - Method in class com.linkedin.venice.throttle.TokenBucket
- getCappedPrefixExtractorLength() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getCatchingUpFollowerLag(String) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
- getCause() - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
-
Returns the cause of the failed I/O operation if the I/O operation has failed.
- getCause() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
- getCause() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
-
Returns the cause of the failed I/O operation if the I/O operation has failed.
- getCause() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
-
Returns the cause of the failed I/O operation if the I/O operation has failed.
- getCause(Throwable, Class<?>...) - Static method in enum class com.linkedin.alpini.base.misc.ExceptionUtil
-
Return the cause of the given
Throwable
if the cause is one of the classes provided; otherwise return the Throwable itself. - getCertificate(Request) - Static method in class com.linkedin.venice.controller.server.AbstractRoute
-
Helper function to get certificate out of Spark request
- getCertificateInRequest() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getCertification(Credentials, Text) - Method in class com.linkedin.venice.hadoop.ssl.TempFileSSLConfigurator
- getChangeCaptureStats() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getChangeFuture() - Method in interface com.linkedin.alpini.router.api.HostFinder
-
Returns an async future which is completed when a change in the routing table occurs.
- getChangelogClientConfig() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getChangelogConsumer(String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
-
Default method to create a
VeniceChangelogConsumer
given a storeName. - getChangelogConsumer(String, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
- getChangelogConsumer(String, String, Class<V>) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
-
Creates a VeniceChangelogConsumer with consumer id.
- getChangelogConsumer(String, String, Class<V>, String) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
- getChannelOptionWriteBufferHighBytes() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getCharSequenceFromGuid(GUID) - Static method in class com.linkedin.venice.guid.GuidUtils
- getCharSequenceMapFromStringMap(Map<String, String>) - Static method in class com.linkedin.venice.utils.CollectionUtils
- getCheckpointUpstreamVersionTopicOffset() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getCheckResourceCleanupForStoreCreationMethod() - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc
- getCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
-
Get the checkSum of the buffer till now.
- getChecksumState() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'checksumState' field.
- getCheckSumState() - Method in class com.linkedin.venice.kafka.validation.Segment
-
`synchronized` keyword will guarantee the caller will always get the checksum after processing the full record in function:
Segment.addToCheckSum(KafkaKey, KafkaMessageEnvelope)
. - getChecksumType() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
-
Gets the value of the 'checksumType' field.
- getChecksumType() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'checksumType' field.
- getCheckSumType() - Method in class com.linkedin.venice.kafka.validation.Segment
- getChecksumValue() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
-
Gets the value of the 'checksumValue' field.
- getChildChannelPool() - Method in class io.netty.handler.codec.http2.EspressoHttp2MultiplexHandler
- getChildControllerAdminTopicConsumptionEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
- getChildControllerD2ServiceName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getChildControllerD2ServiceName(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get child datacenter controller d2 service name
- getChildControllerD2ServiceName(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getChildControllerD2ServiceName(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getChildControllerD2ZkHost(String) - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getChildControllers(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
- getChildControllerUrl(String) - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getChildDataCenterControllerD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getChildDataCenterControllerD2Map() - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
- getChildDataCenterControllerD2Map(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get child datacenter to child controller d2 zk host mapping
- getChildDataCenterControllerD2Map(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getChildDataCenterControllerD2Map(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getChildDataCenterControllerUrlMap() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
-
Map where keys are logical, human-readable names for child clusters (suitable for printing in logs or other output) values are a list of cluster URLs that can be used to reach that cluster with the controller client.
- getChildDataCenterControllerUrlMap() - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
- getChildDataCenterControllerUrlMap(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get child datacenter to child controller url mapping.
- getChildDataCenterControllerUrlMap(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getChildDataCenterControllerUrlMap(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getChildDataCenterKafkaUrlMap() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getChildDataCenterKafkaUrlMap() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getChildDatacenters() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getChildNames(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- getChildren(ZkBaseDataAccessor<T>, String, int, long) - Static method in class com.linkedin.venice.utils.HelixUtils
- getChildValues(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
-
N.B.: The behavior of this function is different from that of
HelixDataAccessor
, which would swallow exceptions and return an empty collection. - getChildValuesMap(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
-
N.B.: The behavior of this function is different from that of
HelixDataAccessor
, which would swallow exceptions and return an empty collection. - getChunk(int) - Method in class com.linkedin.venice.listener.response.ParallelMultiKeyResponseWrapper
- getChunked() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
-
Gets the value of the 'chunked' field.
- getChunked() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'chunked' field.
- getChunkedKeySuffix() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
-
Gets the value of the 'chunkedKeySuffix' field.
- getChunkedKeySuffixBytes() - Method in class com.linkedin.venice.chunking.RawKeyBytesAndChunkedKeySuffix
- getChunkedResponse() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getChunkedResponse() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getChunkedValueManifest() - Method in class com.linkedin.venice.writer.ChunkedPayloadAndManifest
- getChunkId() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
-
Gets the value of the 'chunkId' field.
- getChunkIndex() - Method in class com.linkedin.venice.storage.protocol.ChunkId
-
Gets the value of the 'chunkIndex' field.
- getChunkingEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'chunkingEnabled' field.
- getChunkingEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getChunkingEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'chunkingEnabled' field.
- getChunkingEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'chunkingEnabled' field.
- getChunkingEnabled() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'chunkingEnabled' field.
- getChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'chunkingEnabled' field.
- getChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'chunkingEnabled' field.
- getCiphers(Provider, SslProvider) - Static method in class com.linkedin.alpini.netty4.http2.SSLContextBuilder
- getClassHash() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
- getClassName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
- getClassName() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
- getClassName() - Method in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
- getClassName() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- getClassOverhead(Class<?>) - Static method in class com.linkedin.venice.memory.ClassSizeEstimator
-
This function provides the "shallow size" of each instance of the given class, meaning that all pointers are considered to be null.
- getClasspath() - Static method in class com.linkedin.venice.utils.ForkedJavaProcess
- getClassSchema() - Static method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
- getClassSchema() - Static method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
- getClassSchema() - Static method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
- getClassSchema() - Static method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
- getClassSchema() - Static method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
- getClassSchema() - Static method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.Count
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.DotProduct
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
- getClassSchema() - Static method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- getClassSchema() - Static method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
- getClassSchema() - Static method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
- getClassSchema() - Static method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
- getClassSchema() - Static method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
- getClassSchema() - Static method in enum class com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
- getClassSchema() - Static method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
- getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
- getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
- getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
- getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
- getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
- getClassSchema() - Static method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.ControlMessage
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.Delete
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.EndOfPush
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.EndOfSegment
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.GUID
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.Put
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfPush
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.StartOfSegment
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.PartitionState
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.TopicSwitch
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.Update
- getClassSchema() - Static method in class com.linkedin.venice.kafka.protocol.VersionSwap
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
- getClassSchema() - Static method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
- getClassSchema() - Static method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
- getClassSchema() - Static method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
- getClassSchema() - Static method in class com.linkedin.venice.metadata.response.VersionProperties
- getClassSchema() - Static method in class com.linkedin.venice.participant.protocol.KillPushJob
- getClassSchema() - Static method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
- getClassSchema() - Static method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
- getClassSchema() - Static method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
- getClassSchema() - Static method in class com.linkedin.venice.pushstatus.PushStatusKey
- getClassSchema() - Static method in class com.linkedin.venice.pushstatus.PushStatusValue
- getClassSchema() - Static method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
- getClassSchema() - Static method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
- getClassSchema() - Static method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
- getClassSchema() - Static method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
- getClassSchema() - Static method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
- getClassSchema() - Static method in class com.linkedin.venice.status.protocol.PushJobDetails
- getClassSchema() - Static method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
- getClassSchema() - Static method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
- getClassSchema() - Static method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
- getClassSchema() - Static method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
- getClassSchema() - Static method in class com.linkedin.venice.storage.protocol.ChunkId
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreProperties
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreVersion
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
- getClassSchema() - Static method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
- getCleanedExecutionIds() - Method in class com.linkedin.venice.controllerapi.CleanExecutionIdsResponse
- getClient() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getClient() - Method in class com.linkedin.venice.httpclient.HttpClientUtils.ClosableHttpAsyncClientWithConnManager
- getClient(String, String, DaVinciConfig, Class, CachingDaVinciClientFactory.DaVinciClientConstructor, Class, boolean) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getClientAccessMethod() - Method in enum class com.linkedin.venice.common.VeniceSystemStoreType
- getClientAddress() - Method in class com.linkedin.venice.controller.grpc.server.GrpcControllerClientDetails
- getClientCertificate() - Method in class com.linkedin.venice.controller.grpc.server.GrpcControllerClientDetails
- getClientComputeHeader() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
- getClientComputeHeader() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getClientConfig() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getClientConfig() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- getClientConfig() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getClientConfig() - Method in class com.linkedin.venice.fastclient.InternalAvroStoreClient
- getClientConfigForConsumer() - Method in class com.linkedin.venice.server.VeniceServerContext
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'clientDecompressionEnabled' field.
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getClientDecompressionEnabled() - Method in interface com.linkedin.venice.meta.Store
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.StoreInfo
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.SystemStore
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'clientDecompressionEnabled' field.
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.meta.ZKStore
- getClientDecompressionEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'clientDecompressionEnabled' field.
- getClientDetails(Context) - Static method in class com.linkedin.venice.controller.grpc.server.ControllerGrpcServerUtils
- getClientResolutionRetryAttempts() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getClientResolutionRetryBackoffMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getClientRoutingStrategyType() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getClientSslHandshakeQueueCapacity() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getClientStats(MetricsRepository, String, RequestType, ClientConfig, ClientType) - Static method in class com.linkedin.venice.client.stats.BasicClientStats
- getClientStats(MetricsRepository, String, RequestType, ClientConfig, ClientType) - Static method in class com.linkedin.venice.client.stats.ClientStats
- getClientStats(MetricsRepository, String, String, RequestType) - Static method in class com.linkedin.venice.fastclient.stats.FastClientStats
- getClosableProducer(String, Config, MetricsRegistry) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Convenience method to hide the ugliness of casting in just one place.
- getCloudConfig(CloudProvider, String, List<String>, String, String) - Static method in class com.linkedin.venice.utils.HelixUtils
- getCluster() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
- getCluster() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
- getCluster() - Method in class com.linkedin.venice.datarecovery.Command.Result
- getCluster() - Method in class com.linkedin.venice.meta.StoreConfig
- getCluster() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
-
Gets the value of the 'cluster' field.
- getClusterAdminOpsRequestHandler() - Method in class com.linkedin.venice.controller.server.VeniceControllerRequestHandler
- getClusterDiscoveryD2Service() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getClusterDiscoveryD2ServiceName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getClusterId() - Method in class com.linkedin.venice.controllerapi.AggregatedHealthStatusRequest
- getClusterInfoProvider() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
- getClusterLockManager() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getClusterMaintenanceSignal(String, SafeHelixManager) - Static method in class com.linkedin.venice.utils.HelixUtils
-
If a cluster is in maintenance mode it returns all the signals associated with it regarding the reason and other details for creating the maintenance mode.
- getClusterManagmentTool() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getClusterName() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
-
Gets the value of the 'clusterName' field.
- getClusterName() - Method in class com.linkedin.venice.controller.repush.RepushJobRequest
- getClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
- getClusterName() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
- getClusterName() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getClusterName() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceNoClusterException
- getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceNoStoreException
- getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
- getClusterName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
- getClusterName() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getClusterName() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getClusterName() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfoOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponseOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
-
The cluster name
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
-
The cluster name
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequestOrBuilder
-
The cluster name
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
The cluster name
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
The cluster name
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
The cluster name
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
-
string clusterName = 1;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional string clusterName = 4;
- getClusterName() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
optional string clusterName = 4;
- getClusterName() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
optional string clusterName = 4;
- getClusterName() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getClusterName() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'clusterName' field.
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfoOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponseOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
-
The cluster name
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
-
The cluster name
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequestOrBuilder
-
The cluster name
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
The cluster name
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
The cluster name
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
The cluster name
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
-
string clusterName = 1;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequestOrBuilder
-
string clusterName = 1;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional string clusterName = 4;
- getClusterNameBytes() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
optional string clusterName = 4;
- getClusterNameBytes() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
optional string clusterName = 4;
- getClusterNameFromTopicName(String) - Static method in class com.linkedin.venice.controller.kafka.AdminTopicUtils
- getClusterProperties() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getClusters() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getClusters() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getClustersLeaderOf() - Method in interface com.linkedin.venice.controller.Admin
-
Get a list of clusters this controller is a leader of.
- getClustersLeaderOf() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getClustersLeaderOf() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getClusterStaleStores(String) - Method in interface com.linkedin.venice.controller.Admin
- getClusterStaleStores(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getClusterStaleStores(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
This function will iterate over all of Helix Parent Admin's child controllers, in order to ask about stale stores.
- getClusterStaleStores(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getClusterStats() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getClusterStoragePersonas() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getClusterStoragePersonas(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
- getClusterStoragePersonas(String) - Method in interface com.linkedin.venice.controller.Admin
- getClusterStoragePersonas(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getClusterStoragePersonas(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getClusterStoreGrpcInfo(ControllerResponse) - Static method in class com.linkedin.venice.controller.grpc.GrpcRequestResponseConverter
- getClusterStores(String) - Method in interface com.linkedin.venice.controller.Admin
-
Return all stores in a cluster.
- getClusterStores(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getClusterStores(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getClusterStores(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getClusterToD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getClusterToD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getClusterToD2Map() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getClusterToD2String(Map<String, String>) - Static method in class com.linkedin.venice.utils.TestUtils
- getClusterToServerD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getClusterToServerD2Map() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getClusterToServerD2Map() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getCmdParams() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskParams
- getCmdResult() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
- getCoderArguments() - Method in class com.linkedin.venice.beam.consumer.PubSubMessageCoder
- getCoderArguments() - Method in class com.linkedin.venice.beam.consumer.VeniceMessageCoder
- getCollectedNumberOfSamples() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
- getColoStatus() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'coloStatus' field.
- getColoToCurrentVersions() - Method in class com.linkedin.venice.meta.StoreInfo
- getColumnFamilyHandleList() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getColumns() - Method in class com.linkedin.venice.sql.TableDefinition
- getCombinedProperties() - Method in class com.linkedin.davinci.config.VeniceConfigLoader
- getCommand() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
- getCommand() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getCommand(String, CommandLine) - Static method in enum class com.linkedin.venice.Command
- getCommandLine(String[]) - Static method in class com.linkedin.venice.AdminTool
- getCommandType() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
-
Gets the value of the 'commandType' field.
- getCommonComputeSpec() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
-
Generate compute spec for projections, dot-product and cosine-similarity.
- getCommonConfig() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getCommonResultFields() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
-
Generate compute result schema fields for projections, dot-product and cosine-similarity.
- getCompactionManager() - Method in interface com.linkedin.venice.controller.Admin
- getCompactionManager() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getCompactionManager() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getCompiledProtocol() - Method in class com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer
- getCompletedStatusReplicas(String, int) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
- getCompletionReported() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'completionReported' field.
- getComponentName() - Method in class com.linkedin.venice.utils.LogContext
- getComponentType() - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
-
Gets the value of the 'componentType' field.
- getCompressionDictionary() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getCompressionDictionary() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
-
Gets the value of the 'compressionDictionary' field.
- getCompressionDictionary() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'compressionDictionary' field.
- getCompressionStrategy() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getCompressionStrategy() - Method in interface com.linkedin.davinci.listener.response.ReadResponse
- getCompressionStrategy() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
- getCompressionStrategy() - Method in class com.linkedin.venice.compression.VeniceCompressor
- getCompressionStrategy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getCompressionStrategy() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getCompressionStrategy() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy() - Method in class com.linkedin.venice.listener.response.AbstractReadResponse
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getCompressionStrategy() - Method in interface com.linkedin.venice.meta.Store
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.StoreInfo
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.SystemStore
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy() - Method in interface com.linkedin.venice.meta.Version
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.VersionImpl
- getCompressionStrategy() - Method in class com.linkedin.venice.meta.ZKStore
- getCompressionStrategy() - Method in class com.linkedin.venice.metadata.response.VersionProperties
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
uint32 compressionStrategy = 3;
- getCompressionStrategy() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
uint32 compressionStrategy = 3;
- getCompressionStrategy() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
uint32 compressionStrategy = 3;
- getCompressionStrategy() - Method in class com.linkedin.venice.router.api.ContentDecompressResult
- getCompressionStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'compressionStrategy' field.
- getCompressionStrategy(StoreVersionState) - Static method in class com.linkedin.venice.utils.StoreVersionStateUtils
- getCompressionStrategy(Version, String) - Method in class com.linkedin.venice.controller.server.CreateVersion
- getCompressionStrategy(String) - Static method in class com.linkedin.venice.router.api.VeniceResponseDecompressor
- getCompressionStrategyTypesArrayLength() - Static method in enum class com.linkedin.venice.compression.CompressionStrategy
- getCompressionType() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getCompressor() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getCompressor(CompressionStrategy) - Method in class com.linkedin.venice.compression.CompressorFactory
- getCompressor(CompressionStrategy, int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getCompressor(CompressionStrategy, int) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getCompressor(CompressionStrategy, int, CompressorFactory, Map<Integer, ByteBuffer>) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
- getCompressor(CompressionStrategy, String, int) - Method in class com.linkedin.davinci.compression.StorageEngineBackedCompressorFactory
- getCompressor(CompressorFactory, CompressionStrategy, String, String, VeniceProperties) - Static method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputUtils
- getCompressorFactory() - Method in class com.linkedin.davinci.DaVinciBackend
- getCompressorFactory() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getComputedAggregates() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
-
Gets the value of the 'computedAggregates' field.
- getComputeQueueCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getComputeRequest() - Method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
- getComputeRequestLengthInBytes() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
- getComputeRequestOperations() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
-
Generate compute operations for projections, dot-product and cosine-similarity.
- getComputeRequestOperations() - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
- getComputeRequestPath() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getComputeTardyLatencyThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getConcurrentSnapshotUsers(String, int) - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
- getConfig() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getConfig() - Method in class com.linkedin.venice.controllerapi.RoutersClusterConfigResponse
- getConfig() - Method in class com.linkedin.venice.router.RouterServer
- getConfig(VenicePulsarSinkConfig, String) - Static method in class com.linkedin.venice.pulsar.sink.VenicePulsarSink
- getConfigAccessor() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getConfigLoader() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getConfigLoader() - Method in class com.linkedin.venice.server.VeniceServer
- getConfigMap() - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
-
Gets the value of the 'configMap' field.
- getConfigName() - Method in class com.linkedin.venice.utils.Utils.ConfigEntity
- getConfigs() - Method in class com.linkedin.venice.helix.HelixReadOnlyLiveClusterConfigRepository
- getConfigs() - Method in interface com.linkedin.venice.meta.ReadOnlyLiveClusterConfigRepository
-
Get live cluster configs
- getConfigs() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
-
Gets the value of the 'configs' field.
- getConfigService() - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
- getConfiguredMaxRatePerSecond() - Method in class com.linkedin.venice.throttle.EventThrottler
- getConnectableHosts(HashSet<String>, String, int, int) - Method in class com.linkedin.davinci.blobtransfer.client.NettyFileTransferClient
-
A method to get the connectable hosts for the given store, version, and partition This method is only used for checking connectivity to the hosts.
- getConnectedCount() - Method in class com.linkedin.alpini.netty4.handlers.ConnectionControlHandler
- getConnectedCount() - Method in class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
-
Return the current number of connections.
- getConnectedCount() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getConnectedCount() - Method in interface com.linkedin.alpini.router.impl.Router
- getConnectionHandleMode() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getConnectionLimit() - Method in class com.linkedin.alpini.netty4.handlers.ConnectionLimitHandler
-
Return the current connection limit.
- getConnectionLimit() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getConnectionLimit() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getConnectionTimeout() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getConnManager() - Method in class com.linkedin.venice.httpclient.HttpClientUtils.ClosableHttpAsyncClientWithConnManager
- getConsumedKafkaClusterId() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getConsumedPosition() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getConsumedRecordEndToEndProcessingLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
- getConsumedRecordEndToEndProcessingLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
- getConsumer(String, Config, MetricsRegistry) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
- getConsumerAdapterFactory() - Method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- getConsumerAssignedToVersionTopicPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
- getConsumerAssignedToVersionTopicPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- getConsumerAssignedToVersionTopicPartition(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
-
There might be no consumer service found for the version topic and topic partition, which means the topic partition is not subscribed.
- getConsumeRemotely() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'consumeRemotely' field.
- getConsumerIdStr() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- getConsumerIdSuffix() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getConsumerName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getConsumerName() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getConsumerPollTrackerStaleThresholdSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerPoolSizeForCurrentVersionAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerPoolSizeForCurrentVersionNonAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerPoolSizeForCurrentVersionSepRTLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerPoolSizeForNonCurrentVersionAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerPoolSizeForNonCurrentVersionNonAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerPoolSizePerKafkaCluster() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerPoolStrategyType() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getConsumerProperties() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getConsumerProperties(JobConf) - Static method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputUtils
-
Extracts and prepares the Kafka consumer properties for a Venice input job.
- getConsumerServices() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.ConsumerPoolStrategy
- getConsumerServices() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.CurrentVersionConsumerPoolStrategy
- getConsumerServices() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator.DefaultConsumerPoolStrategy
- getConsumptionSnapshots(String, ComplementSet<Integer>) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getConsumptionSnapshots(String, ComplementSet<Integer>) - Method in interface com.linkedin.davinci.storage.IngestionMetadataRetriever
- getConsumptionSnapshots(String, ComplementSet<Integer>) - Method in class com.linkedin.davinci.storage.IngestionMetadataRetrieverDelegator
- getConsumptionSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getConsumptionSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getConsumptionStartTimeInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getContent() - Method in class com.linkedin.davinci.utils.ByteArrayKey
- getContent() - Method in class com.linkedin.venice.router.api.ContentDecompressResult
- getContentInByteBuf() - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
-
Returns the response as ByteBuf.
- getContinueExistingPeriodicTasksAfterShutdownPolicy() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
-
Gets the policy on whether to continue executing existing periodic tasks even when this executor has been
shutdown
. - getControllerAccessManager() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getControllerAccessManager() - Method in class com.linkedin.venice.controller.server.VeniceControllerRequestHandler
- getControllerClient(String, String, D2Client) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
- getControllerClient(String, String, String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.D2ControllerClientFactory
- getControllerClient(String, String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.controllerapi.ControllerClientFactory
- getControllerClientMap(String) - Method in class com.linkedin.venice.controller.systemstore.SystemStoreRepairTask
- getControllerClientMap(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getControllerClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getControllerClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getControllerClusterReplica() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getControllerClusterReplica() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getControllerClusterZkAddress() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getControllerClusterZkAddress() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getControllerConfig(String) - Method in interface com.linkedin.venice.controller.Admin
- getControllerConfig(String) - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getControllerConfig(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getControllerConfig(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getControllerD2ServiceName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getControllerDiscoveryUrl(Config) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
- getControllerDiscoveryUrls() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getControllerHAASSuperClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getControllerHAASSuperClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getControllerInstanceTagList() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getControllerInstanceTagList() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getControllerName() - Method in interface com.linkedin.venice.controller.Admin
- getControllerName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getControllerName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getControllerName() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getControllerName() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getControllerNameToVersionMap() - Method in class com.linkedin.venice.controllerapi.AdminOperationProtocolVersionControllerResponse
- getControllerRequestRetryCount() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getControllerResourceInstanceGroupTag() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getControllersByHelixState(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Get controllers instance based on the given helix state.
- getControlMessageType() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
-
Gets the value of the 'controlMessageType' field.
- getControlMessageUnion() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
-
Gets the value of the 'controlMessageUnion' field.
- getCoordinates() - Method in class com.linkedin.venice.beam.consumer.CheckPointProperties
- getCopyIfNotUsableInCallback() - Method in class com.linkedin.venice.client.store.transport.HttpsTransportClient
-
The same
CloseableHttpAsyncClient
could not be used to send out another request in its own callback function. - getCopyIfNotUsableInCallback() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
-
The same
CloseableHttpAsyncClient
could not be used to send out another request in its own callback function. - getCopyIfNotUsableInCallback() - Method in class com.linkedin.venice.client.store.transport.TransportClient
-
If the internal client could not be used by its callback function, implementation of this function should return a new copy.
- getCorruptedMsg() - Method in class com.linkedin.davinci.stats.DIVStats
- getCosSimilarityParam() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
-
Gets the value of the 'cosSimilarityParam' field.
- getCounterName() - Method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper.GroupAndCounterNames
- getCreatedTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getCreatedTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getCreatedTime() - Method in interface com.linkedin.venice.meta.Store
- getCreatedTime() - Method in class com.linkedin.venice.meta.SystemStore
- getCreatedTime() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'createdTime' field.
- getCreatedTime() - Method in interface com.linkedin.venice.meta.Version
- getCreatedTime() - Method in class com.linkedin.venice.meta.VersionImpl
- getCreatedTime() - Method in class com.linkedin.venice.meta.ZKStore
- getCreatedTime() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'createdTime' field.
- getCreatedTime() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'createdTime' field.
- getCreateStoreMethod() - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc
- getCreateTimestampInMs() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getCreationTime() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'creationTime' field.
- getCredentials() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
- getCurrentContext() - Method in class com.linkedin.venice.schema.vson.VsonReader
-
Deprecated.
- getCurrentDate() - Method in class com.linkedin.venice.utils.MockCircularTime
- getCurrentDate() - Method in class com.linkedin.venice.utils.SystemTime
- getCurrentKey() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
- getCurrentKey() - Method in interface com.linkedin.venice.hadoop.input.recordreader.VeniceRecordIterator
-
Return the current key.
- getCurrentKey() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
- getCurrentLineNumber() - Method in class com.linkedin.venice.schema.vson.VsonReader
-
Deprecated.
- getCurrentLineOffset() - Method in class com.linkedin.venice.schema.vson.VsonReader
-
Deprecated.
- getCurrentOffset() - Method in class com.linkedin.venice.meta.UncompletedReplica
- getCurrentPendingRequestCount() - Method in class com.linkedin.venice.router.throttle.PendingRequestThrottler
- getCurrentProgress() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- getCurrentProtocolVersion() - Method in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
- getCurrentProtocolVersionSchema() - Method in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
- getCurrentRTVersionNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'currentRTVersionNumber' field.
- getCurrentServingVersionTopic() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getCurrentStats() - Method in class com.linkedin.venice.listener.ServerStatsContext
- getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
- getCurrentStatus() - Method in class com.linkedin.venice.pushmonitor.RouterBasedPushMonitor
- getCurrentStep() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getCurrentStepEnum() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getCurrentStoreVersion() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getCurrentStoreVersion() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getCurrentTermStartPubSubPosition() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'currentTermStartPubSubPosition' field.
- getCurrentThrottlerRate() - Method in class com.linkedin.davinci.kafka.consumer.VeniceAdaptiveIngestionThrottler
- getCurrentTimeInNanos() - Method in class com.linkedin.davinci.listener.response.NoOpReadResponseStats
- getCurrentTimeInNanos() - Method in interface com.linkedin.davinci.listener.response.ReadResponseStats
- getCurrentTimeInNanos() - Method in class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- getCurrentUser() - Static method in class com.linkedin.venice.utils.Utils
- getCurrentValue() - Method in class com.linkedin.davinci.consumer.ChangeEvent
- getCurrentValue() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
-
Gets the value of the 'currentValue' field.
- getCurrentValue() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
- getCurrentValue() - Method in interface com.linkedin.venice.hadoop.input.recordreader.VeniceRecordIterator
-
Return the current value.
- getCurrentValue() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
- getCurrentVersion() - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
- getCurrentVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
- getCurrentVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
- getCurrentVersion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
-
Gets the value of the 'currentVersion' field.
- getCurrentVersion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'currentVersion' field.
- getCurrentVersion() - Method in class com.linkedin.venice.controllerapi.CurrentVersionResponse
- getCurrentVersion() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getCurrentVersion() - Method in class com.linkedin.venice.fastclient.RequestContext
- getCurrentVersion() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getCurrentVersion() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getCurrentVersion() - Method in interface com.linkedin.venice.meta.Store
- getCurrentVersion() - Method in class com.linkedin.venice.meta.StoreInfo
-
The version of the store which is currently being served
- getCurrentVersion() - Method in class com.linkedin.venice.meta.SystemStore
- getCurrentVersion() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
-
Gets the value of the 'currentVersion' field.
- getCurrentVersion() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'currentVersion' field.
- getCurrentVersion() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
- getCurrentVersion() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
- getCurrentVersion() - Method in class com.linkedin.venice.meta.ZKStore
- getCurrentVersion() - Method in class com.linkedin.venice.metadata.response.VersionProperties
-
Gets the value of the 'currentVersion' field.
- getCurrentVersion() - Method in class com.linkedin.venice.stats.ServerReadQuotaUsageStats
- getCurrentVersion() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'currentVersion' field.
- getCurrentVersion() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
-
Gets the value of the 'currentVersion' field.
- getCurrentVersion(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
-
return
Store.NON_EXISTING_VERSION
if current version doesn't exist. - getCurrentVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getCurrentVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getCurrentVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getCurrentVersionAAWCLeaderQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getCurrentVersionHeartbeatLag() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.AggregatedHeartbeatLagEntry
- getCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getCurrentVersionResponse(String) - Method in interface com.linkedin.davinci.storage.ReadMetadataRetriever
- getCurrentVersionResponse(String) - Method in class com.linkedin.venice.listener.ServerReadMetadataRepository
- getCurrentVersionSepRTLeaderQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getCurrentVersionsForMultiColos(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getCurrentVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getCurrentVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Query the current version for the given store.
- getCurrentVersionStates() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
-
Gets the value of the 'currentVersionStates' field.
- getCurrentWorkingDirectory() - Static method in class com.linkedin.venice.utils.Utils
- getCustomizedViewRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getCustomMetricPrefix() - Method in class com.linkedin.venice.stats.metrics.MetricEntity
- getD2BasePath() - Method in class com.linkedin.venice.client.store.ClientConfig
- getD2Client() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getD2Client() - Method in class com.linkedin.venice.client.store.ClientConfig
- getD2Client() - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
- getD2Client() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getD2Client() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getD2Client(String, Optional<SSLFactory>) - Static method in class com.linkedin.venice.d2.D2ClientFactory
- getD2ControllerClient() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getD2Service() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
- getD2Service() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string d2Service = 3;
- getD2Service() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string d2Service = 3;
- getD2Service() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string d2Service = 3;
- getD2ServiceBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string d2Service = 3;
- getD2ServiceBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string d2Service = 3;
- getD2ServiceBytes() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string d2Service = 3;
- getD2ServiceName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getD2ServiceName() - Method in class com.linkedin.venice.client.store.ClientConfig
- getD2ServiceName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getD2ServiceName() - Method in class com.linkedin.venice.controllerapi.ChildAwareResponse
- getD2ServiceName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
- getD2ServiceName(String) - Static method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
- getD2ZkTimeout() - Method in class com.linkedin.venice.client.store.ClientConfig
- getDanglingTopicCleanupIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDanglingTopicCleanupIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDanglingTopicOccurrenceThresholdForCleanup() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDanglingTopicOccurrenceThresholdForCleanup() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getData() - Method in class com.linkedin.davinci.store.record.ValueRecord
- getData() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
bytes data = 2;
- getData() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
bytes data = 2;
- getData() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
bytes data = 2;
- getDataAge() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getDatabaseInfo() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'databaseInfo' field.
- getDatabaseInfo() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getDatabaseLookupQueueCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDatabaseOpenOperationThrottle() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getDataBasePath() - Method in class com.linkedin.davinci.config.VeniceServerConfig
-
Get base path of Venice storage data.
- getDatabaseSyncBytesInterval() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
-
Gets the databaseSyncBytesInterval.
- getDatabaseSyncBytesIntervalForDeferredWriteMode() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDatabaseSyncBytesIntervalForTransactionalMode() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDatacenterCount(String) - Method in interface com.linkedin.venice.controller.Admin
-
number of datacenters, 1 if in single cluster mode.
- getDatacenterCount(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getDataInBytes() - Method in class com.linkedin.davinci.store.record.ValueRecord
- getDataRecordDeserializer(int) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getDataRecordDeserializer(int) - Method in class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
- getDataRecordDeserializer(int) - Method in class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
- getDataRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getDataRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingAvroSpecificStoreClient
- getDataRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingVsonStoreClient
-
Deprecated.
- getDataRecoveryConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'dataRecoveryConfig' field.
- getDataRecoverySourceFabric() - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
- getDataRecoverySourceFabric() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
- getDataRecoverySourceFabric() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
-
Gets the value of the 'dataRecoverySourceFabric' field.
- getDataRecoverySourceVersionNumber() - Method in interface com.linkedin.venice.meta.DataRecoveryVersionConfig
- getDataRecoverySourceVersionNumber() - Method in class com.linkedin.venice.meta.DataRecoveryVersionConfigImpl
- getDataRecoverySourceVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
-
Gets the value of the 'dataRecoverySourceVersionNumber' field.
- getDataRecoveryVersionConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getDataRecoveryVersionConfig() - Method in interface com.linkedin.venice.meta.Version
- getDataRecoveryVersionConfig() - Method in class com.linkedin.venice.meta.VersionImpl
- getDataReplicationPolicy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
-
Gets the value of the 'dataReplicationPolicy' field.
- getDataReplicationPolicy() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
- getDataReplicationPolicy() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- getDataReplicationPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
-
Gets the value of the 'dataReplicationPolicy' field.
- getDataReplicationPolicyMap() - Static method in enum class com.linkedin.venice.meta.DataReplicationPolicy
- getDataSchema() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
- getDataSize() - Method in class com.linkedin.davinci.store.record.ValueRecord
- getDataWriterTaskTracker() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- getDataWriterTaskTracker() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
- getDateTime() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
- getDaVinciClientForMetaStore() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getDaVinciCurrentVersion() - Method in class com.linkedin.davinci.StoreBackend
- getDaVinciCurrentVersionBootstrappingQuotaBytesPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDaVinciCurrentVersionBootstrappingQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDaVinciPartitionLevelPushStatusAndDetails(PushStatusStoreReader, String, int, Optional<String>, int, double, boolean, Set<CharSequence>) - Static method in class com.linkedin.venice.pushmonitor.PushMonitorUtils
- getDaVinciPushStatusAndDetails(PushStatusStoreReader, String, int, Optional<String>, int, double, boolean) - Static method in class com.linkedin.venice.pushmonitor.PushMonitorUtils
-
This method checks Da Vinci client push status for the target version from push status store and compute a final status.
- getDaVinciPushStatusCheckIntervalInMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDaVinciPushStatusScanIntervalInSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDaVinciPushStatusScanMaxOfflineInstanceCount() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDaVinciPushStatusScanMaxOfflineInstanceRatio() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDaVinciPushStatusScanNoReportRetryMaxAttempt() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDaVinciPushStatusScanThreadNumber() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'daVinciPushStatusStoreEnabled' field.
- getDaVinciPushStatusStoreEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'daVinciPushStatusStoreEnabled' field.
- getDaVinciPushStatusStoreName(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
- getDaVinciRecordTransformerStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getDeadStores(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getDeadStores(String, boolean, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getDeadStores(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
- getDeadStores(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getDeadStores(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getDeadStores(List<StoreInfo>) - Method in interface com.linkedin.venice.controller.stats.DeadStoreStats
-
Side effect operation of populating isStoreDead and setStoreDeadStatusReasons in the StoreInfo object and returns back the same list of StoreInfo objects.
- getDeadStoreStatsClassName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDeadStoreStatsConfigs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDeadStoreStatsPreFetchRefreshIntervalInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDebug() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getDebugInfo() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
-
Gets the value of the 'debugInfo' field.
- getDebugInfo() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'debugInfo' field.
- getDebugInfo() - Method in class com.linkedin.venice.kafka.validation.Segment
- getDebugInfo() - Static method in class com.linkedin.venice.utils.Utils
- getDecompressionTimeInNs() - Method in class com.linkedin.venice.router.api.ContentDecompressResult
- getDecompressionTimeInNs() - Method in class com.linkedin.venice.router.api.VeniceFullHttpResponse
- getDedicatedConsumerPoolSizeForAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDedicatedConsumerPoolSizeForSepRTLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDefaultConfigs() - Method in class com.linkedin.venice.hooks.StoreLifecycleHooks
- getDefaultDeserializationExecutor() - Static method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getDefaultFormat() - Static method in enum class com.linkedin.venice.stats.VeniceOpenTelemetryMetricNamingFormat
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
- getDefaultInstance() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
- getDefaultInstanceForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
- getDefaultMaxRecordSizeBytes() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDefaultMaxRecordSizeBytes() - Method in interface com.linkedin.venice.controller.Admin
- getDefaultMaxRecordSizeBytes() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDefaultMaxRecordSizeBytes() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDefaultMaxRecordSizeBytes() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getDefaultMaxRecordSizeBytes() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getDefaultReadQuotaPerRouter() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDefaultRetryExecutor() - Static method in class com.linkedin.venice.client.store.RetriableStoreClient
- getDefaultTimeoutMillis() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- getDefaultValue() - Method in class com.linkedin.venice.sql.ColumnDefinition
- getDefaultValue() - Method in class com.linkedin.venice.utils.Utils.ConfigEntity
- getDeferredVersionSwapBufferTime() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDeferredVersionSwapBufferTime() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDeferredVersionSwapSleepMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDeferredVersionSwapSleepMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDeferredWrite() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'deferredWrite' field.
- getDeferVersionSwap() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'deferVersionSwap' field.
- getDefinition() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
-
Gets the value of the 'definition' field.
- getDelayToRebalanceMS() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDelegate() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
-
Subclasses should be able to access the delegate, but other classes should not, otherwise they could keep a handle on the delegate, while the delegate may later be swapped via
DelegatingStorageEngine.setDelegate(StorageEngine)
. - getDelegateTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
- getDeletableStoreTopics() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getDeletableStoreTopics(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getDeleteAclForStoreMethod() - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc
- getDeletedElements() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- getDeletedElementTimestamps() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- getDeletedResource() - Method in class com.linkedin.venice.helix.ResourceAssignment.ResourceAssignmentChanges
- getDELETEDTS() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
-
Gets the value of the 'DELETED_TS' field.
- getDeleteErrorCount() - Method in class com.linkedin.davinci.stats.DaVinciRecordTransformerStats
- getDeleteLatencySensor() - Method in class com.linkedin.davinci.stats.DaVinciRecordTransformerStats
- getDeleting() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
-
Gets the value of the 'deleting' field.
- getDeprecatedJobTopicMaxRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDeprecatedJobTopicMaxRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDeprecatedJobTopicRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDeprecatedJobTopicRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDerivedSchema(int, int) - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
-
Retrieve update schema and annotate top-level string array and map field's field update and collection merge operations.
- getDerivedSchema(int, int) - Method in class com.linkedin.venice.schema.SchemaData
- getDerivedSchema(String, int, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getDerivedSchema(String, int, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getDerivedSchema(String, int, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
- getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getDerivedSchema(String, int, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getDerivedSchema(String, int, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
- getDerivedSchema(String, String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getDerivedSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
-
Gets the value of the 'derivedSchemaId' field.
- getDerivedSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
- getDerivedSchemaId() - Method in class com.linkedin.venice.controllerapi.SchemaResponse
- getDerivedSchemaId(String) - Method in class com.linkedin.venice.schema.SchemaData
- getDerivedSchemaId(String, String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getDerivedSchemaId(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getDerivedSchemaId(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
- getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getDerivedSchemaId(String, String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getDerivedSchemaId(String, String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Look up derived schema id and its corresponding value schema id by given store name and derived schema.
- getDerivedSchemaId(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
- getDerivedSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getDerivedSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getDerivedSchemas() - Method in class com.linkedin.venice.schema.SchemaData
- getDerivedSchemas(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getDerivedSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getDerivedSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
- getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getDerivedSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getDerivedSchemas(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getDerivedSchemas(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
- getDerivedSchemas(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getDerivedSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getDerivedSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getDerivedValueSchemaId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
- getDesc() - Method in enum class com.linkedin.venice.Command
- getDescription() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
optional string description = 3;
- getDescription() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
-
optional string description = 3;
- getDescription() - Method in interface com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponseOrBuilder
-
optional string description = 3;
- getDescription() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets a human readable description of this validation result.
- getDescription() - Method in class com.linkedin.venice.stats.metrics.MetricEntity
- getDescription() - Method in class com.linkedin.venice.status.StoreStatusMessage
- getDescriptionBytes() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
optional string description = 3;
- getDescriptionBytes() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
-
optional string description = 3;
- getDescriptionBytes() - Method in interface com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponseOrBuilder
-
optional string description = 3;
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceOuterClass
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- getDescriptor() - Static method in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.ControllerGrpcRequestContext
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceOuterClass
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- getDescriptor() - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceOuterClass
- getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceClientRequest
- getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceOuterClass
- getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
- getDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceServerResponse
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
- getDescriptorForType() - Method in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
- getDescriptorForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
- getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.ClientConfig
- getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- getDeserializationExecutor() - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
- getDeserializationExecutor() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getDeserializedValue() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
-
Provide the deserialized new value on a best-effort approach.
- getDeserializer() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
- getDeserializer(int) - Method in class com.linkedin.davinci.consumer.RmdDeserializerCache
- getDeserializer(int) - Method in class com.linkedin.venice.serialization.avro.AvroSpecificStoreDeserializerCache
- getDeserializer(int) - Method in class com.linkedin.venice.serialization.AvroStoreDeserializerCache
- getDeserializer(int) - Method in class com.linkedin.venice.serialization.RawBytesStoreDeserializerCache
- getDeserializer(int) - Method in interface com.linkedin.venice.serialization.StoreDeserializerCache
- getDeserializer(int, int) - Method in class com.linkedin.davinci.consumer.RmdDeserializerCache
- getDeserializer(int, int) - Method in class com.linkedin.venice.serialization.avro.AvroSpecificStoreDeserializerCache
- getDeserializer(int, int) - Method in class com.linkedin.venice.serialization.AvroStoreDeserializerCache
- getDeserializer(int, int) - Method in class com.linkedin.venice.serialization.RawBytesStoreDeserializerCache
- getDeserializer(int, int) - Method in interface com.linkedin.venice.serialization.StoreDeserializerCache
- getDeserializer(Schema, Schema) - Static method in class com.linkedin.davinci.serializer.avro.fast.MapOrderPreservingFastSerDeFactory
- getDeserializer(Schema, Schema) - Static method in class com.linkedin.davinci.serializer.avro.MapOrderPreservingSerDeFactory
- getDeserializerFromFactory(Schema, Schema) - Method in class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
- getDeserializerFromFactory(Schema, Schema) - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
-
Deprecated.
- getDestClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
-
Gets the value of the 'destClusterName' field.
- getDestClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
-
Gets the value of the 'destClusterName' field.
- getDestFabric() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getDestination() - Method in class com.linkedin.venice.writer.VeniceWriter
- getDestinationCluster() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getDetail() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
-
Gets the value of the 'detail' field.
- getDetails() - Method in class com.linkedin.venice.controller.NodeRemovableResult
- getDetails() - Method in class com.linkedin.venice.controllerapi.NodeStatusResponse
- getDetails() - Method in class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
- getDictionaryFromResponse(PortableHttpResponse, String) - Method in class com.linkedin.venice.router.api.DictionaryRetrievalService
- getDictionaryRetrievalTimeMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getDimensionName() - Method in enum class com.linkedin.venice.read.RequestType
-
All the instances of this Enum should have the same dimension name.
- getDimensionName() - Method in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusCodeCategory
-
All the instances of this Enum should have the same dimension name.
- getDimensionName() - Method in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
-
All the instances of this Enum should have the same dimension name.
- getDimensionName() - Method in enum class com.linkedin.venice.stats.dimensions.MessageType
-
All the instances of this Enum should have the same dimension name.
- getDimensionName() - Method in enum class com.linkedin.venice.stats.dimensions.RequestRetryAbortReason
-
All the instances of this Enum should have the same dimension name.
- getDimensionName() - Method in enum class com.linkedin.venice.stats.dimensions.RequestRetryType
-
All the instances of this Enum should have the same dimension name.
- getDimensionName() - Method in interface com.linkedin.venice.stats.dimensions.VeniceDimensionInterface
-
Dimension name: Returns the
VeniceMetricsDimensions
for the enum. - getDimensionName() - Method in enum class com.linkedin.venice.stats.dimensions.VeniceResponseStatusCategory
-
All the instances of this Enum should have the same dimension name.
- getDimensionName(VeniceMetricsDimensions) - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- getDimensionName(VeniceOpenTelemetryMetricNamingFormat) - Method in enum class com.linkedin.venice.stats.dimensions.VeniceMetricsDimensions
- getDimensionNameInDefaultFormat() - Method in enum class com.linkedin.venice.stats.dimensions.VeniceMetricsDimensions
- getDimensionsList() - Method in class com.linkedin.venice.stats.metrics.MetricEntity
- getDimensionValue() - Method in enum class com.linkedin.venice.read.RequestType
- getDimensionValue() - Method in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusCodeCategory
- getDimensionValue() - Method in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusEnum
- getDimensionValue() - Method in enum class com.linkedin.venice.stats.dimensions.MessageType
- getDimensionValue() - Method in enum class com.linkedin.venice.stats.dimensions.RequestRetryAbortReason
- getDimensionValue() - Method in enum class com.linkedin.venice.stats.dimensions.RequestRetryType
- getDimensionValue() - Method in interface com.linkedin.venice.stats.dimensions.VeniceDimensionInterface
-
Dimension value: Returns the dimension value for each enum instance.
- getDimensionValue() - Method in enum class com.linkedin.venice.stats.dimensions.VeniceResponseStatusCategory
- getDisableDavinciPushStatusStore() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'disableDavinciPushStatusStore' field.
- getDisabledPartitionsMap(String, String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Returns a list of disabled partitions in an instance.
- getDisabledPartitionsMap(String, String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- getDisabledPartitionStats(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getDisabledReplicaEnablerServiceIntervalMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDisabledReplicaEnablerServiceIntervalMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDisabledRoutes() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getDisabledRoutes() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getDisabledRoutes() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getDisableMetaStore() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'disableMetaStore' field.
- getDisableReplicaCallback(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getDisableStoreView() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getDiscoverClusterForStoreMethod() - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc
- getDiscoveryResult() - Method in class com.linkedin.venice.blobtransfer.BlobPeersDiscoveryResponse
- getDiskFullThreshold() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDiskHealthCheckIntervalInMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDiskHealthCheckTimeoutInMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDiskQuotaUsage() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
- getDiskStatus() - Method in class com.linkedin.venice.utils.DiskUsage
- getDiskUsage() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getDispatchMinimumMillis() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- getDivProducerStateMaxAgeMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDnsCacheRefreshIntervalInMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getDoc() - Method in class com.linkedin.venice.utils.Utils.ConfigEntity
- getDotProductParam() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
-
Gets the value of the 'dotProductParam' field.
- getDouble(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getDouble(String, double) - Method in class com.linkedin.venice.utils.VeniceProperties
- getDoUpdateSupersetSchemaID() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
-
Gets the value of the 'doUpdateSupersetSchemaID' field.
- getDrainerForConsumerRecord(DefaultPubSubMessage, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- getDrainerIndexForConsumerRecord(DefaultPubSubMessage, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- getDrainerPoolSizeSortedInput() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDrainerPoolSizeUnsortedInput() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDuckDBUrl() - Method in class com.linkedin.venice.duckdb.DuckDBDaVinciRecordTransformer
- getDummyCommand() - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- getDummyContent() - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- getDummyKey() - Static method in class com.linkedin.venice.utils.PubSubHelper
- getDummyKey(boolean) - Static method in class com.linkedin.venice.utils.PubSubHelper
- getDummyPubSubMessage(boolean) - Static method in class com.linkedin.venice.utils.PubSubHelper
- getDummyValue() - Static method in class com.linkedin.venice.utils.PubSubHelper
- getDummyValue(long) - Static method in class com.linkedin.venice.utils.PubSubHelper
- getDuplicateKeyCountEstimate() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineStats
- getDuplicateKeyCountEstimate() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getDuplicateKeyCountEstimate() - Method in class com.linkedin.davinci.store.StorageEngineNoOpStats
- getDuplicateKeyCountEstimate() - Method in interface com.linkedin.davinci.store.StorageEngineStats
- getDuplicateKeyWithDistinctCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getDuplicateKeyWithDistinctCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getDuplicateKeyWithDistinctValueCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getDuplicateKeyWithDistinctValueCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getDuplicateKeyWithDistinctValueCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getDuplicateKeyWithDistinctValueCount() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getDuplicateMsg() - Method in class com.linkedin.davinci.stats.DIVStats
- getDurationInSec(OfflinePushStatus) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getDvcP2pBlobTransferClientPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getDvcP2pBlobTransferServerPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getElapsedTimeFromMsToMs(long) - Static method in class com.linkedin.venice.utils.LatencyUtils
- getElapsedTimeFromNSToMS(long) - Static method in class com.linkedin.venice.utils.LatencyUtils
- getElapsedTimeSinceLastConsumerPollInMs() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- getElapsedTimeSinceLastRecordForPartitionInMs() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- getEmergencySourceRegion() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getEmergencySourceRegion() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getEmergencySourceRegion(String) - Method in interface com.linkedin.venice.controller.Admin
-
Return the emergency source region configuration.
- getEmergencySourceRegion(String) - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getEmergencySourceRegion(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getEmergencySourceRegion(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
-
Gets the value of the 'enabled' field.
- getEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
-
Gets the value of the 'enabled' field.
- getEnabledSystemStoreTypes(Store) - Static method in enum class com.linkedin.venice.common.VeniceSystemStoreType
-
Get a list of enabled Venice system store types based on the given regular Venice Store object.
- getEnableReads() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'enableReads' field.
- getEnableReads() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getEnableReads() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'enableReads' field.
- getEnableReads() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'enableReads' field.
- getEnableWrites() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'enableWrites' field.
- getEnableWrites() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getEnableWrites() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'enableWrites' field.
- getEnableWrites() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'enableWrites' field.
- getEncodedState() - Method in class com.linkedin.venice.kafka.validation.checksum.AdHash
- getEncodedState() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
- getEncodedState() - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
- getEndingOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
-
Returns the ending offset for the split
- getEndOffset(String, int) - Method in class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
-
Get the end offset of a topic partition
- getEndOfPush() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'endOfPush' field.
- getEndOfPushTimestamp() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getEndOfPushTimestamp() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'endOfPushTimestamp' field.
- getEnforcementInterval() - Method in class com.linkedin.venice.throttle.TokenBucket
- getEngineTaskConfigProvider() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
- getEntryFromDnsCache(String) - Method in class com.linkedin.venice.httpclient.CachedDnsResolver
- getEnumValuesList(Class<V>) - Static method in class com.linkedin.venice.utils.EnumUtils
-
Lots of defensive coding to ensure that control message type values are: 1.
- getEnumValuesSparseList(Class<V>) - Static method in class com.linkedin.venice.utils.EnumUtils
-
This is a relaxed version of
EnumUtils.getEnumValuesList(Class)
which returns a map instead of a list. - getEnv() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getEnvelopeDeserializer(int) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
- getEnvelopeDeserializer(int) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
- getEnvelopeDeserializer(int) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
- getEnvOptions() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getEquivalentKafkaClusterIdForSepTopic(int) - Method in class com.linkedin.davinci.config.VeniceClusterConfig
-
For the separate incremental push topic feature, we need to resolve the cluster id to the original one for monitoring purposes as the incremental push topic essentially uses the same pubsub clusters as the regular push topic, though it appears to have a different cluster id
- getError() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
- getError() - Method in class com.linkedin.venice.datarecovery.Command.Result
- getError() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
- getError() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
-
Gets the value of the 'error' field.
- getErrorCode() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
uint32 errorCode = 6;
- getErrorCode() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
uint32 errorCode = 6;
- getErrorCode() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
uint32 errorCode = 6;
- getErrorCount() - Method in class com.linkedin.alpini.netty4.handlers.Http2SettingsFrameLogger
- getErrorInstances() - Method in class com.linkedin.venice.meta.Partition
- getErrorMessage() - Method in class com.linkedin.davinci.storage.DiskHealthCheckService
- getErrorMessage() - Method in class com.linkedin.venice.blobtransfer.BlobPeersDiscoveryResponse
- getErrorMessage() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getErrorMessage() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
string errorMessage = 2;
- getErrorMessage() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
string errorMessage = 2;
- getErrorMessage() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
string errorMessage = 2;
- getErrorMessage() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
string errorMessage = 7;
- getErrorMessage() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
string errorMessage = 7;
- getErrorMessage() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
string errorMessage = 7;
- getErrorMessage(String, String, String) - Static method in exception com.linkedin.venice.exceptions.QuotaExceededException
- getErrorMessageBytes() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
string errorMessage = 2;
- getErrorMessageBytes() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
string errorMessage = 2;
- getErrorMessageBytes() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
string errorMessage = 2;
- getErrorMessageBytes() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
string errorMessage = 7;
- getErrorMessageBytes() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
string errorMessage = 7;
- getErrorMessageBytes() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
string errorMessage = 7;
- getErrorPartitionAutoResetLimit() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getErrorPartitionProcessingCycleDelay() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getErrorReported() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'errorReported' field.
- getErrorStream() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
- getErrorType() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
- getErrorType() - Method in exception com.linkedin.venice.exceptions.VeniceException
-
Returns the errorType.
- getErrorType() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional .com.linkedin.venice.protocols.controller.ControllerGrpcErrorType errorType = 3;
- getErrorType() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
optional .com.linkedin.venice.protocols.controller.ControllerGrpcErrorType errorType = 3;
- getErrorType() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
optional .com.linkedin.venice.protocols.controller.ControllerGrpcErrorType errorType = 3;
- getErrorTypeValue() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional .com.linkedin.venice.protocols.controller.ControllerGrpcErrorType errorType = 3;
- getErrorTypeValue() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
optional .com.linkedin.venice.protocols.controller.ControllerGrpcErrorType errorType = 3;
- getErrorTypeValue() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
optional .com.linkedin.venice.protocols.controller.ControllerGrpcErrorType errorType = 3;
- getEstimatedRecoveryTimeInSeconds() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
- getEstimator() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
- getEtlConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'etlConfig' field.
- getETLedProxyUserAccount() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getEtledUserProxyAccount() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
-
Gets the value of the 'etledUserProxyAccount' field.
- getEtledUserProxyAccount() - Method in interface com.linkedin.venice.meta.ETLStoreConfig
- getEtledUserProxyAccount() - Method in class com.linkedin.venice.meta.ETLStoreConfigImpl
- getEtledUserProxyAccount() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
-
Gets the value of the 'etledUserProxyAccount' field.
- getEtledUserProxyAccount() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
-
Gets the value of the 'etledUserProxyAccount' field.
- getETLFileSchema(Schema, Schema) - Static method in class com.linkedin.venice.utils.TestWriteUtils
- getETLFileSchemaWithNullDefaultValue(Schema, Schema) - Static method in class com.linkedin.venice.utils.TestWriteUtils
- getEtlStoreConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getEtlStoreConfig() - Method in interface com.linkedin.venice.meta.Store
- getEtlStoreConfig() - Method in class com.linkedin.venice.meta.StoreInfo
- getEtlStoreConfig() - Method in class com.linkedin.venice.meta.SystemStore
- getEtlStoreConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'etlStoreConfig' field.
- getEtlStoreConfig() - Method in class com.linkedin.venice.meta.ZKStore
- getETLStoreConfig() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'ETLStoreConfig' field.
- getExceedQuotaFlag() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- getExceedQuotaFlag() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
- getException() - Method in class com.linkedin.venice.pubsub.adapter.PubSubProducerCallbackSimpleImpl
- getExceptionThrown() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'exceptionThrown' field.
- getExceptionType() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
-
Deprecated.
- getExceptionType() - Method in enum class com.linkedin.venice.exceptions.ErrorType
- getExecuteExistingDelayedTasksAfterShutdownPolicy() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
-
Gets the policy on whether to execute existing delayed tasks even when this executor has been
shutdown
. - getExecution() - Method in class com.linkedin.venice.controllerapi.routes.AdminCommandExecutionResponse
- getExecution(Admin, ClusterAdminOpsRequestHandler) - Method in class com.linkedin.venice.controller.server.AdminCommandExecutionRoutes
-
No ACL check; any user is allowed to check admin command execution status.
- getExecutionId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
-
Gets the value of the 'executionId' field.
- getExecutionId() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
- getExecutionId() - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
- getExecutionId() - Method in class com.linkedin.venice.controllerapi.RepushJobResponse
- getExecutionId() - Method in class com.linkedin.venice.controllerapi.TrackableControllerResponse
- getExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 executionId = 2;
- getExecutionId() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
optional int64 executionId = 2;
- getExecutionId() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
optional int64 executionId = 2;
- getExecutionId(Map<String, Long>) - Static method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
- getExecutionIdAccessor() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getExecutionStatus() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
- getExecutionStatus() - Method in class com.linkedin.venice.routerapi.PushStatusResponse
- getExecutionStatusByInstanceId(String) - Method in class com.linkedin.venice.meta.Partition
- getExecutor() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
- getExecutor() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
- getExecutorService() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumptionTask
- getExecutorService(String) - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
- getExecutorService(String) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelDualPoolFactory
- getExistingHttpPipelineInitializer() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- getExitCode() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
- getExpectedChecksum() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getExpectedNumberOfPartitions() - Method in class com.linkedin.venice.meta.PartitionAssignment
- getExpectedRetentionTimeInMs(Store, HybridStoreConfig) - Static method in class com.linkedin.venice.utils.StoreUtils
-
The default retention time for the RT topic is defined in
PubSubConstants.DEFAULT_TOPIC_RETENTION_POLICY_MS
, but if the rewind time is larger than this, then the RT topic's retention time needs to be set even higher, in order to guarantee that buffer replays do not lose data. - getExpectedRouterCount() - Method in class com.linkedin.venice.meta.RoutersClusterConfig
- getExpectedRoutersCount() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
- getExpectedRoutersCount() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
-
Get the expected number of routers in the cluster.
- getExpectedValue() - Method in class com.linkedin.venice.client.store.predicate.RecordFieldProjectionEqualsPredicate
- getExponentialHistogramPointData(Collection<MetricData>, String, String) - Static method in class com.linkedin.venice.utils.OpenTelemetryDataPointTestUtils
- getExportOtelMetricsIntervalInSeconds() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getExternalSupersetSchemaGenerator() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getExtra() - Method in class com.linkedin.venice.sql.ColumnDefinition
- getExtraDetails() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
- getExtraDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
-
Deprecated.Only used for JSON serialization purposes. Use
JobStatusQueryResponse.getOptionalExtraDetails()
instead. - getExtraInfo() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
- getExtraInfo() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
-
N.B.: The values in this map conform to
ExecutionStatus
values. - getExtraInfoUpdateTimestamp() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
- getExtraInfoUpdateTimestamp() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
-
N.B.: Older versions of the controller did not support these timestamps, so this map can be null.
- getFabricToExecutionStatusMap() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
- getFabricToExecutionStatusMap() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
Deprecated.
- getFabricToExecutionStatusMap() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
Deprecated.
- getFabricToExecutionStatusMap() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
Deprecated.
- getFabricToExecutionStatusMapCount() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
- getFabricToExecutionStatusMapCount() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- getFabricToExecutionStatusMapCount() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapMap() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapMap() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapMap() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapOrDefault(String, String) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapOrDefault(String, String) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapOrDefault(String, String) - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapOrThrow(String) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapOrThrow(String) - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFabricToExecutionStatusMapOrThrow(String) - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
map<string, string> fabricToExecutionStatusMap = 5;
- getFactoryByTypeId(int) - Method in class com.linkedin.venice.pubsub.PubSubPositionTypeRegistry
-
Returns the fully qualified class name of the
PubSubPositionFactory
implementation - getFailedIngestionPartitionCount() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getFailingOffset() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
- getFailureDetails() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'failureDetails' field.
- getFailureReason() - Method in interface com.linkedin.venice.jobs.ComputeJob
- getFailureReason() - Method in class com.linkedin.venice.jobs.DataWriterComputeJob
- getFanoutSize() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
- getFastAvroFieldLimitPerMethod() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getFastAvroGenericDeserializer(Schema, Schema) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
- getFastAvroGenericSerializer(Schema) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
- getFastAvroGenericSerializer(Schema, boolean) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
- getFastAvroSpecificDeserializer(Schema, Class<V>) - Static method in class com.linkedin.venice.serializer.FastSerializerDeserializerFactory
- getFastClassSchemaWarmupTimeout() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getFatalDataValidationFailureRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getFatalDataValidationFailureRetentionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getField() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
-
Gets the value of the 'field' field.
- getField() - Method in class com.linkedin.venice.compute.protocol.request.Count
-
Gets the value of the 'field' field.
- getField() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
-
Gets the value of the 'field' field.
- getField() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
-
Gets the value of the 'field' field.
- getField(Object, String, int) - Static method in class com.linkedin.venice.utils.AvroCompatibilityUtils
-
Backport getField() method implementation from GenericData in avro v1.7
- getFieldDefault(Schema.Field) - Static method in class com.linkedin.venice.utils.AvroSchemaUtils
-
Non-throwing flavor of AvroCompatibilityHelper.getGenericDefaultValue, returns null if there is no default.
- getFieldIndex(StructType, String) - Static method in class com.linkedin.venice.spark.utils.SparkScalaUtils
-
Get the index of a field in a StructType.
- getFieldName() - Method in class com.linkedin.venice.client.store.predicate.RecordFieldProjectionEqualsPredicate
- getFieldName() - Method in exception com.linkedin.venice.hadoop.exceptions.VeniceSchemaFieldNotFoundException
- getFieldOperationType(Object) - Static method in enum class com.linkedin.venice.schema.writecompute.WriteComputeOperation
- getFields() - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
- getFields() - Method in class com.linkedin.venice.status.StatusMessage
-
Get K-V paris of all the fields in message.
- getFields() - Method in class com.linkedin.venice.status.StoreStatusMessage
- getFilePath() - Method in class com.linkedin.venice.spark.input.hdfs.VeniceHdfsInputPartition
- getFileSchema(FileSystem, Path) - Static method in class com.linkedin.venice.hadoop.input.recordreader.avro.HdfsAvroUtils
- getFilledSize() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
- getFilterChain(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
- getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.AdHash
- getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.Adler32CheckSum
- getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
- getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
- getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
- getFinalCheckSum() - Method in class com.linkedin.venice.kafka.validation.Segment
- getFinalReturnStatus(Map<String, ExecutionStatus>, Set<String>, int, StringBuilder) - Static method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Based on the global information, start determining the final status to return
- getFinalSegment() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
-
Gets the value of the 'finalSegment' field.
- getFineGrainedPercentileStat(String, int, double) - Static method in class com.linkedin.venice.stats.TehutiUtils
- getFineGrainedPercentileStat(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
- getFineGrainedPercentileStatWithAvgAndMax(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
- getFirst() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
-
Returns the first element in this list.
- getFirst() - Method in class com.linkedin.alpini.base.misc.Pair
-
Return the first value.
- getFirst() - Method in class com.linkedin.venice.utils.Pair
-
Deprecated.
- getFirstHeader(String) - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
- getFirstSendHeartbeatException() - Method in class com.linkedin.venice.heartbeat.NoOpPushJobHeartbeatSender
- getFirstSendHeartbeatException() - Method in interface com.linkedin.venice.heartbeat.PushJobHeartbeatSender
-
Get first exception encountered while it is sending heartbeats.
- getFlushIntervalMs() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getFollowerBytesConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
- getFollowerHeartbeatTimeStamps() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- getFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
Measure the offset lag between follower and leader
- getFollowerOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getFollowerRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
- getForkedProcessJvmArgList() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getFormattedMessage() - Method in class com.linkedin.venice.controller.NodeRemovableResult
- getForRead() - Method in interface com.linkedin.venice.meta.AbstractStore.StoreVersionSupplier
-
This function will return a list of Versions, which are read-only, and any modification against them will throw
UnsupportedOperationException
. - getForUpdate() - Method in interface com.linkedin.venice.meta.AbstractStore.StoreVersionSupplier
-
This function will return a reference to the internal versions structure, and any change applying to the returned object will be reflected in the referenced
Store
. - getFreePort() - Static method in class com.linkedin.venice.utils.TestUtils
-
WARNING: The code which generates the free port and uses it must always be called within a try/catch and a loop.
- getFullMetricName(String) - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
- getFullPathForTempSSTFileDir() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- getFullPathForTempSSTFileDir() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getFullPendingQueueServerOORMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getFullResourceName() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- getFuture() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getFutureVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
- getFutureVersion() - Method in class com.linkedin.davinci.stats.VeniceVersionedStatsReporter
- getFutureVersion() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Result
- getFutureVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getFutureVersion(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
-
return
Store.NON_EXISTING_VERSION
if future version doesn't exist. - getFutureVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getFutureVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getFutureVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller and returns Store.NON_EXISTING_VERSION.
- getFutureVersionETLEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
-
Gets the value of the 'futureVersionETLEnabled' field.
- getFutureVersionETLEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getFutureVersionETLEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
-
Gets the value of the 'futureVersionETLEnabled' field.
- getFutureVersionETLEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
-
Gets the value of the 'futureVersionETLEnabled' field.
- getFutureVersions(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getFutureVersionsForMultiColos(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getFutureVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getFutureVersionsForMultiColos(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getFutureVersionWithStatus(String, String, VersionStatus) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getGeneratedSchemaVersion() - Method in class com.linkedin.venice.schema.GeneratedSchemaID
- getGenericAvroClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getGenericAvroClient(String, DaVinciConfig) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getGenericAvroClient(String, DaVinciConfig) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getGenericAvroClient(String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getGenericAvroClient(String, String, DaVinciConfig) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getGenericAvroClient(String, String, DaVinciConfig) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getGenericRecordChunkingAdapter() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- getGenericThinClient() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getGetAclForStoreMethod() - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc
- getGetAdminCommandExecutionStatusMethod() - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc
- getGetAdminTopicMetadataMethod() - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc
- getGetLastSuccessfulAdminCommandExecutionIdMethod() - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc
- getGetLeaderControllerMethod() - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc
- getGetMethod() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
- getGlobalChannelTrafficShapingHandlerInstance(long, long) - Static method in class com.linkedin.davinci.blobtransfer.BlobTransferGlobalTrafficShapingHandlerHolder
-
Gets the singleton instance of GlobalChannelTrafficShapingHandler.
- getGlobalRtDivEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'globalRtDivEnabled' field.
- getGlobalRtDivEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'globalRtDivEnabled' field.
- getGlobalRtDivEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'globalRtDivEnabled' field.
- getGlobalRtDivKeyBytes(String) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getGlobalRtDivKeyName(String) - Static method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
-
The Global RT DIV is produced on a per-broker basis, so the name includes the broker URL for differentiation.
- getGlobalShutdownDelayMillis() - Static method in class com.linkedin.alpini.base.registry.ResourceRegistry
-
Get the delay for global shutdown.
- getGraveyardCleanupSleepIntervalBetweenListFetchMinutes() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getGroupCount() - Method in class com.linkedin.venice.fastclient.meta.HelixGroupRoutingStrategy
- getGroupCount() - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
- getGroupCount() - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
- getGroupIds() - Method in class com.linkedin.venice.fastclient.meta.HelixGroupInfo
- getGroupName() - Method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper.GroupAndCounterNames
- getGroupResponseWaitingTimeAvg(int) - Method in class com.linkedin.venice.stats.routing.HelixGroupStats
- getGrpcClientConfig() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getGrpcPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getGrpcPort() - Method in class com.linkedin.venice.meta.Instance
- getGrpcServerThreadCount() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getGrpcServerThreadCount() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getGrpcSslPort() - Method in class com.linkedin.venice.meta.Instance
- getGrpcSslUrl() - Method in class com.linkedin.venice.meta.Instance
- getGrpcStatsContext() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
- getGrpcUrl() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
- getGrpcUrl() - Method in class com.linkedin.venice.meta.Instance
- getGrpcUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
gRPC URL for leader controller
- getGrpcUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
gRPC URL for leader controller
- getGrpcUrl() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
gRPC URL for leader controller
- getGrpcUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
gRPC URL for leader controller
- getGrpcUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
gRPC URL for leader controller
- getGrpcUrlBytes() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
gRPC URL for leader controller
- getGrpcWorkerThreadCount() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getGuid() - Method in class com.linkedin.venice.guid.DeterministicGuidGenerator
- getGuid() - Method in class com.linkedin.venice.guid.HeartbeatGuidV3Generator
- getGuid() - Method in class com.linkedin.venice.guid.JavaUtilGuidV4Generator
- getGUID(VeniceProperties) - Static method in class com.linkedin.venice.guid.GuidUtils
- getGuidFromCharSequence(CharSequence) - Static method in class com.linkedin.venice.guid.GuidUtils
- getGuidFromHex(String) - Static method in class com.linkedin.venice.guid.GuidUtils
- getGUIDString() - Static method in class com.linkedin.venice.guid.GuidUtils
- getHadamardProductParam() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
-
Gets the value of the 'hadamardProductParam' field.
- getHadoopUserCredentials() - Static method in class com.linkedin.venice.hadoop.ssl.UserCredentialsFactory
-
Get user's credentials from the current Hadoop user group context.
- getHandler(Class<T>) - Method in class com.linkedin.venice.helix.HelixStatusMessageChannel
-
Get the handler for given Venice message type.
- getHandshakesFailed() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Returns the number of handshakes which had resulted in failure.
- getHandshakesStarted() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Returns the number of handshakes which have been started.
- getHandshakesSuccessful() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Returns the number of handshakes which had resulted in success.
- getHarClusters() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getHasLingeringResources() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
bool hasLingeringResources = 2;
- getHasLingeringResources() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
-
bool hasLingeringResources = 2;
- getHasLingeringResources() - Method in interface com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponseOrBuilder
-
bool hasLingeringResources = 2;
- getHealthReportCollector() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getHealthyRegions() - Method in class com.linkedin.venice.meta.StoreDataAudit
- getHealthyRequestHttpStatus(int) - Static method in class com.linkedin.venice.client.stats.BasicClientStats
-
Get the HTTP status code for healthy requests based on the number of successful keys as both null and valid values are considered healthy in Venice.
- getHeapSize() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
- getHeapSize() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getHeapSize() - Method in interface com.linkedin.venice.memory.Measurable
- getHeapSize() - Method in class com.linkedin.venice.message.KafkaKey
- getHeapSize() - Method in class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPosition
- getHeapSize() - Method in class com.linkedin.venice.pubsub.api.EmptyPubSubMessageHeaders
- getHeapSize() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeader
-
TODO: the following estimation doesn't consider the overhead of the internal structure.
- getHeapSize() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageHeaders
- getHeapSize() - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterConcurrentDelegator.ProducerQueueNode
- getHeapSize() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getHeapSize() - Method in class com.linkedin.venice.unit.kafka.InMemoryPubSubPosition
- getHeapSize() - Method in class com.linkedin.venice.utils.collections.MeasurableLinkedHashMap
- getHeapSize() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getHeapSize() - Method in class com.linkedin.venice.writer.CompletableFutureCallback
- getHeartbeat() - Method in class com.linkedin.davinci.kafka.consumer.ReplicaHeartbeatInfo
- getHeartbeat(String) - Method in class com.linkedin.venice.system.store.MetaStoreReader
- getHeartbeat(String, String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getHeartbeatCycleMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHeartbeatFromSystemStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getHeartbeatFromSystemStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getHeartbeatFromSystemStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Read the latest heartbeat timestamp from system store.
- getHeartbeatFromSystemStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getHeartbeatFromSystemStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getHeartbeatInfo(String, int, boolean) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- getHeartbeatInitialDelay() - Method in class com.linkedin.venice.heartbeat.NoOpPushJobHeartbeatSender
- getHeartbeatInitialDelay() - Method in interface com.linkedin.venice.heartbeat.PushJobHeartbeatSender
- getHeartBeatIntervalSeconds() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getHeartbeatKey(String) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getHeartbeatKME(long, LeaderMetadataWrapper, ControlMessage, String) - Static method in class com.linkedin.venice.writer.VeniceWriter
- getHeartbeatLag(String, int, boolean) - Method in interface com.linkedin.davinci.storage.IngestionMetadataRetriever
- getHeartbeatLag(String, int, boolean) - Method in class com.linkedin.davinci.storage.IngestionMetadataRetrieverDelegator
- getHeartbeatMonitoringService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getHeartbeatMonitoringService() - Method in class com.linkedin.venice.server.VeniceServer
- getHeartbeatReporterThread() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getHeartBeatRequestTimeoutMS() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getHeartbeatSendInterval() - Method in class com.linkedin.venice.heartbeat.NoOpPushJobHeartbeatSender
- getHeartbeatSendInterval() - Method in interface com.linkedin.venice.heartbeat.PushJobHeartbeatSender
- getHeartbeatTimeoutMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHeartbeatTimestamp() - Method in class com.linkedin.venice.controllerapi.SystemStoreHeartbeatResponse
- getHeartbeatTimestamp() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'heartbeatTimestamp' field.
- getHelixAdmin() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getHelixAdminClient() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getHelixCloudConfig() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixClusterZkPath(String) - Static method in class com.linkedin.venice.utils.HelixUtils
- getHelixDataAccessor() - Method in class com.linkedin.venice.helix.SafeHelixManager
-
This function is incompatible with the
HelixManager
interface, since the return type ofSafeHelixDataAccessor
is not compatible with the return of the unsafe interface, which is aHelixDataAccessor
. - getHelixDefaultInstanceCapacityMap() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixDefaultPartitionWeightMap() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixGlobalRebalancePreference() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixGroupId() - Method in class com.linkedin.venice.fastclient.RequestContext
- getHelixGroupId() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getHelixGroupId() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getHelixGroupId(long, int) - Method in class com.linkedin.venice.fastclient.meta.AbstractClientRoutingStrategy
- getHelixGroupId(long, int) - Method in class com.linkedin.venice.fastclient.meta.HelixGroupRoutingStrategy
- getHelixGroupId(long, int) - Method in class com.linkedin.venice.fastclient.meta.HelixLeastLoadedGroupRoutingStrategy
-
Get the least loaded group based on the response time collected in the past.
- getHelixGroupInfo() - Method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
-
Gets the value of the 'helixGroupInfo' field.
- getHelixGroupInfo() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'helixGroupInfo' field.
- getHelixGroupInfoMap() - Method in class com.linkedin.venice.fastclient.meta.HelixGroupInfo
- getHelixGroupSelectionStrategy() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHelixInstanceCapacityKeys() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixManager() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getHelixNodeIdentifier(String, int) - Static method in class com.linkedin.venice.utils.Utils
- getHelixParticipationService() - Method in class com.linkedin.venice.server.VeniceServer
- getHelixPropertyStore() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getHelixReadOnlyStoreRepository() - Method in class com.linkedin.davinci.helix.HelixParticipationService
- getHelixRebalanceAlg() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixRestCustomizedHealthUrl() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixSendMessageTimeoutMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getHelixStateByInstanceId(String) - Method in class com.linkedin.venice.meta.Partition
-
Find the status of given instance in this partition.
- getHelixVeniceClusterResources(String) - Method in interface com.linkedin.venice.controller.Admin
- getHelixVeniceClusterResources(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getHelixVeniceClusterResources(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getHelpText() - Method in enum class com.linkedin.venice.Arg
- getHexFromGuid(GUID) - Static method in class com.linkedin.venice.guid.GuidUtils
- getHistogramPointData(Collection<MetricData>, String, String) - Static method in class com.linkedin.venice.utils.OpenTelemetryDataPointTestUtils
- getHitCount() - Method in class com.linkedin.davinci.store.cache.backend.StoreCacheStats
- getHitRate() - Method in class com.linkedin.davinci.store.cache.backend.StoreCacheStats
- getHost() - Method in class com.linkedin.venice.meta.Instance
- getHostLevelIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getHostname() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHostname() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getHostName() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
-
Gets the value of the 'hostName' field.
- getHostName() - Static method in class com.linkedin.venice.utils.Utils
-
Get the node's host name.
- getHostPatternForDnsCache() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHosts() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
- getHostUrl(boolean) - Method in class com.linkedin.venice.meta.Instance
- getHttp2Headers() - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getHttp2HeaderTableSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getHttp2HeaderTableSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttp2InitialWindowSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getHttp2InitialWindowSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttp2MaxConcurrentStreams() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getHttp2MaxConcurrentStreams() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttp2MaxFrameSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getHttp2MaxFrameSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttp2MaxHeaderListSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getHttp2MaxHeaderListSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttp2PipelineInitializerBuilderSupplier() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- getHttp2PipelineInitializerBuilderSupplier() - Method in class com.linkedin.alpini.router.impl.netty4.Router4PipelineFactory
- getHttp2Settings() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- getHttp2SettingsFrameLogger() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- getHttp2SettingsFrameLogger() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getHttpasyncclientConnectionWarmingExecutorThreadNum() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpasyncclientConnectionWarmingLowWaterMark() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpasyncclientConnectionWarmingNewInstanceDelayJoinMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpasyncclientConnectionWarmingSleepIntervalMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpasyncclientConnectionWarmingSocketTimeoutMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpClient5PoolSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpClient5TotalIOThreadCount() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpClientForHost(String) - Method in class com.linkedin.venice.router.httpclient.ApacheHttpAsyncStorageNodeClient
- getHttpClientPoolSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getHttpMethod() - Method in enum class com.linkedin.venice.controllerapi.ControllerRoute
- getHttpMethod() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getHttpMethod() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getHttpMethod() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- getHttpResponseStatus() - Method in exception com.linkedin.venice.exceptions.VeniceRouterException
- getHttpResponseStatus() - Static method in exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
- getHttpStatus() - Method in exception com.linkedin.venice.client.exceptions.VeniceClientHttpException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.PartitionerSchemaMismatchException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.QuotaExceededException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.ResourceStillExistsException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceAclException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceException
-
If this exception is caught in handling an http request, what status code should be returned? Exceptions that extend VeniceException can override this for different behavior
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceHttpException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceNoClusterException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceNoStoreException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
- getHttpStatusCode() - Method in exception com.linkedin.venice.exceptions.VeniceUnsupportedOperationException
- getHttpStatusCode() - Method in exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
- getHttpsUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
SSL-enabled leader controller URL
- getHttpsUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
SSL-enabled leader controller URL
- getHttpsUrl() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
SSL-enabled leader controller URL
- getHttpsUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
SSL-enabled leader controller URL
- getHttpsUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
SSL-enabled leader controller URL
- getHttpsUrlBytes() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
SSL-enabled leader controller URL
- getHttpUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
Leader controller URL
- getHttpUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
Leader controller URL
- getHttpUrl() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
Leader controller URL
- getHttpUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
Leader controller URL
- getHttpUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
Leader controller URL
- getHttpUrlBytes() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
Leader controller URL
- getHybrid() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'hybrid' field.
- getHybrid() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'hybrid' field.
- getHybridBufferReplayPolicy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getHybridConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'hybridConfig' field.
- getHybridConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'hybridConfig' field.
- getHybridDataReplicationPolicy() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getHybridFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getHybridFollowerOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getHybridFollowerOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getHybridLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getHybridLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getHybridLeaderOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getHybridOffsetLagThreshold() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getHybridQuotaMonitorTask() - Method in class com.linkedin.venice.pushmonitor.RouterBasedHybridStoreQuotaMonitor
- getHybridQuotaReplicaStatus(String, int) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
- getHybridQuotaViolatedStores() - Method in class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
-
Get list of quota exceeded stores from local memory cache.
- getHybridRewindSeconds() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getHybridStoreConfig() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'hybridStoreConfig' field.
- getHybridStoreConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getHybridStoreConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getHybridStoreConfig() - Method in interface com.linkedin.venice.meta.Store
- getHybridStoreConfig() - Method in class com.linkedin.venice.meta.StoreInfo
- getHybridStoreConfig() - Method in class com.linkedin.venice.meta.SystemStore
- getHybridStoreConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'hybridStoreConfig' field.
- getHybridStoreConfig() - Method in interface com.linkedin.venice.meta.Version
- getHybridStoreConfig() - Method in class com.linkedin.venice.meta.VersionImpl
- getHybridStoreConfig() - Method in class com.linkedin.venice.meta.ZKStore
- getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'hybridStoreDiskQuotaEnabled' field.
- getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'hybridStoreDiskQuotaEnabled' field.
- getHybridStoreDiskQuotaEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'hybridStoreDiskQuotaEnabled' field.
- getHybridStoreOverheadBypass() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'hybridStoreOverheadBypass' field.
- getHybridStoreOverheadBypass() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getHybridStoreOverheadBypass() - Method in class com.linkedin.venice.meta.StoreInfo
- getHybridStoreQuotaStatus(String) - Method in class com.linkedin.venice.helix.HelixHybridStoreQuotaRepository
-
Get hybrid store quota status from local memory cache for specific resource name.
- getHybridTimeLagThreshold() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getIcProvider() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getIcProvider() - Method in class com.linkedin.venice.server.VeniceServerContext
- getId() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
-
Gets the value of the 'id' field.
- getId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
- getId() - Method in class com.linkedin.venice.controllerapi.SchemaResponse
- getId() - Method in class com.linkedin.venice.meta.Partition
- getId() - Method in class com.linkedin.venice.schema.SchemaEntry
- getIdealState(String, String, SafeHelixManager) - Static method in class com.linkedin.venice.utils.HelixUtils
- getIdentityParserClassName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIdentityParserClassName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getIdentityParserClassName() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getIdleConnectionToServerCleanupThresholdMins() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getIdleIngestionTaskCleanupIntervalInSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIdleTime() - Method in class com.linkedin.davinci.stats.IngestionStats
- getIdx() - Method in class com.linkedin.venice.schema.rmd.v1.ElementTimestampAndIdx
- getIfPresent(K) - Method in class com.linkedin.davinci.store.cache.caffeine.CaffeineVeniceStoreCache
- getIfPresent(K) - Method in interface com.linkedin.davinci.store.cache.VeniceStoreCache
-
Returns the value associated with the
key
in this cache, ornull
if there is no cached value for thekey
. - getIgnoredResult() - Static method in class com.linkedin.davinci.replication.merge.MergeConflictResult
- getIncrementalPushEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'incrementalPushEnabled' field.
- getIncrementalPushEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getIncrementalPushEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'incrementalPushEnabled' field.
- getIncrementalPushEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'incrementalPushEnabled' field.
- getIncrementalPushEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'incrementalPushEnabled' field.
- getIncrementalPushInfo() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'incrementalPushInfo' field.
- getIncrementalPushJobTimeInMs(String) - Static method in class com.linkedin.venice.pushmonitor.StatusSnapshot
-
Incremental push job version id follows such pattern: timestampInMs_hadoopClusterName_jobExecutionId
- getIncrementalPushPolicy() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'incrementalPushPolicy' field.
- getIncrementalPushPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'incrementalPushPolicy' field.
- getIncrementalPushPolicy() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'incrementalPushPolicy' field.
- getIncrementalPushPolicyToApply() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
-
Gets the value of the 'incrementalPushPolicyToApply' field.
- getIncrementalPushPolicyToFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
-
Gets the value of the 'incrementalPushPolicyToFilter' field.
- getIncrementalPushStatus(PartitionAssignment, String) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
-
Returns map of partitionId -> list of status history for all working replicas of that partition
- getIncrementalPushStatusAndDetails(String, String, HelixCustomizedViewOfflinePushRepository) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getIncrementalPushStatusAndDetails(String, String, HelixCustomizedViewOfflinePushRepository) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
-
Returns incremental push's status read from (ZooKeeper backed) OfflinePushStatus
- getIncrementalPushStatusAndDetails(String, String, HelixCustomizedViewOfflinePushRepository) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getIncrementalPushStatusFromPushStatusStore(String, String, HelixCustomizedViewOfflinePushRepository, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getIncrementalPushStatusFromPushStatusStore(String, String, HelixCustomizedViewOfflinePushRepository, PushStatusStoreReader) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
-
Returns incremental push's status read from push status store
- getIncrementalPushStatusFromPushStatusStore(String, String, HelixCustomizedViewOfflinePushRepository, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getIncrementalPushStatusWriteMode() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIncrementalPushVersion() - Method in class com.linkedin.venice.hadoop.VenicePushJob
- getIncrementalPushVersion() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getIncrementalPushVersion() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- getIncrementalPushVersion() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
- getIncrementalPushVersion(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
- getIncrementalPushVersion(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getIncrementalPushVersion(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
A couple of extra checks are needed in parent controller 1.
- getIncrementalPushVersions() - Method in class com.linkedin.venice.controllerapi.IncrementalPushVersionsResponse
- getIndex(String) - Method in class com.linkedin.venice.utils.RedundantExceptionFilter
- getIndexType() - Method in class com.linkedin.venice.sql.ColumnDefinition
- getInFlightRequestRate() - Method in class com.linkedin.venice.router.InFlightRequestStat
- getInFlightRequestRate() - Method in class com.linkedin.venice.router.RouterServer
- getIngestingPartitionCount() - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
- getIngestingTopicsWithVersionStatusNotOnline() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getIngestingTopicsWithVersionStatusNotOnline() - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
-
Get topic names that are currently maintained by the ingestion service with corresponding version status not in an online state.
- getIngestionActionFromRequest(HttpRequest) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- getIngestionApplicationPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIngestionBackend() - Method in class com.linkedin.davinci.DaVinciBackend
- getIngestionBackend() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- getIngestionBackend() - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
- getIngestionBackend() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getIngestionBatchProcessor() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- getIngestionBatchProcessor() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getIngestionBatchProcessor() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getIngestionHeartbeatIntervalMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIngestionInfoFor(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
- getIngestionInfoFor(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- getIngestionInfoFor(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
- getIngestionIsolationPropertyMap() - Static method in class com.linkedin.venice.utils.TestUtils
- getIngestionMemoryLimit() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIngestionMode() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIngestionNotifier() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
- getIngestionServicePort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getIngestionTask() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
- getIngestionTask() - Method in class com.linkedin.davinci.stats.IngestionStats
- getIngestionTaskErroredGauge() - Method in class com.linkedin.davinci.stats.IngestionStats
- getIngestionTaskMaxIdleCount() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getIngestionTaskName() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getIngestionTaskPushTimeoutGauge() - Method in class com.linkedin.davinci.stats.IngestionStats
- getInnerClientConfig() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getInnerStoreClient() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- getInputDataInfoProvider() - Method in class com.linkedin.venice.hadoop.VenicePushJob
- getInputFileDataSize() - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
-
Gets the value of the 'inputFileDataSize' field.
- getInputFileDataSizeInBytes() - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
- getInputLastModificationTime(String) - Method in class com.linkedin.venice.hadoop.DefaultInputDataInfoProvider
- getInputLastModificationTime(String) - Method in interface com.linkedin.venice.hadoop.InputDataInfoProvider
- getInputLastModificationTime(String) - Method in class com.linkedin.venice.hadoop.KafkaInputDataInfoProvider
- getInputModificationTime() - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
- getInputStream() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
- getInputURI(VeniceProperties) - Method in class com.linkedin.venice.hadoop.VenicePushJob
-
Get input path from the properties; Check whether there is sub-directory in the input directory
- getInputValueSchema() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
-
Returns the schema for the input value used in
DaVinciClient
's operations. - getInstance() - Static method in class com.linkedin.alpini.base.concurrency.impl.CancelledAsyncFuture
- getInstance() - Method in class com.linkedin.davinci.helix.HelixParticipationService
- getInstance() - Static method in class com.linkedin.davinci.replication.merge.MergeConflictResolverFactory
- getInstance() - Static method in class com.linkedin.venice.guid.HeartbeatGuidV3Generator
- getInstance() - Static method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
- getInstance() - Method in class com.linkedin.venice.helix.Replica
- getInstance() - Static method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
- getInstance() - Static method in class com.linkedin.venice.serialization.IdentityRecordDeserializer
- getInstance() - Static method in class com.linkedin.venice.serialization.RawBytesStoreDeserializerCache
- getInstance() - Static method in class com.linkedin.venice.utils.ObjectMapperFactory
- getInstance(int, int, byte[]) - Method in class com.linkedin.venice.helix.AbstractSchemaEntrySerializer
- getInstance(int, int, byte[]) - Method in class com.linkedin.venice.helix.DerivedSchemaEntrySerializer
- getInstance(int, int, byte[]) - Method in class com.linkedin.venice.helix.ReplicationMetadataSchemaEntrySerializer
- getInstance(AbstractAvroStoreClient) - Static method in class com.linkedin.venice.store.StoreStateReader
- getInstance(ClientConfig) - Static method in class com.linkedin.venice.store.StoreStateReader
- getInstance(ClientConfig, VeniceProperties) - Static method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getInstance(ClientConfig, VeniceProperties, ICProvider) - Static method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getInstance(CheckSumType) - Static method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
- getInstance(CheckSumType, byte[]) - Static method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
- getInstanceFromHelixInstanceName(String) - Static method in class com.linkedin.venice.utils.HelixUtils
- getInstanceGroupId(String) - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
- getInstanceGroupId(String) - Method in class com.linkedin.venice.router.api.routing.helix.HelixGroupSelector
- getInstanceGroupIdMapping() - Method in class com.linkedin.venice.helix.HelixInstanceConfigRepository
- getInstanceHealthMonitor() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getInstanceHealthMonitor() - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
- getInstanceHealthMonitor() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getInstanceHealthMonitor() - Method in class com.linkedin.venice.fastclient.RequestContext
- getInstanceId() - Method in class com.linkedin.venice.controller.NodeRemovableResult
- getInstanceId() - Method in class com.linkedin.venice.meta.ReplicaDetail
- getInstanceId() - Method in class com.linkedin.venice.meta.UncompletedReplica
- getInstanceId() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- getInstanceId() - Method in class com.linkedin.venice.status.StoreStatusMessage
- getInstanceIdFromReplicaId(String) - Static method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- getInstanceName() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getInstances() - Method in class com.linkedin.venice.controllerapi.AggregatedHealthStatusRequest
- getInstances() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
-
Gets the value of the 'instances' field.
- getInstancesInCluster(String) - Method in interface com.linkedin.venice.controller.HelixAdminClient
-
Get a list of instances under a cluster.
- getInstancesInCluster(String) - Method in class com.linkedin.venice.controller.ZkHelixAdminClient
- getInstancesInState(HelixState) - Method in class com.linkedin.venice.meta.Partition
- getInstancesInState(ExecutionStatus) - Method in class com.linkedin.venice.meta.Partition
- getInstancesStatusMap() - Method in class com.linkedin.venice.controllerapi.MultiNodesStatusResponse
- getInstanceStatus(String, String) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getInstanceToHelixStateMap() - Method in class com.linkedin.venice.meta.Partition
- getInstanceType() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getInt(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getInt(CharSequence, int) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getInt(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getInt(String, int) - Method in class com.linkedin.venice.utils.VeniceProperties
- getInterceptors() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
- getInternalPreprocessingLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
- getInternalPreprocessingLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
- getInternalProducer() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
- getInternalStorageEngineFactory(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.storage.StorageService
-
This method should ideally be Private, but marked as public for validating the result.
- getIntHeaderFromByteBuffer(ByteBuffer) - Static method in class com.linkedin.venice.utils.ByteUtils
-
Extract an integer header from the ByteBuffer provided.
- getIntKeyedMap(String) - Method in class com.linkedin.venice.utils.VeniceProperties
-
Retrieves a map from the configuration using the given key, where keys are expected to be integers and values are strings.
- getInUseSchemaIds(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getInUseSchemaIds(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getInUseValueSchemaIds() - Method in class com.linkedin.venice.controllerapi.SchemaUsageResponse
- getInUseValueSchemaIds(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getInUseValueSchemaIds(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getInUseValueSchemaIds(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getIoThreadCountInPoolMode() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getIsAborted() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getIsBatchRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
bool isBatchRequest = 9;
- getIsBatchRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
bool isBatchRequest = 9;
- getIsBatchRequest() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
bool isBatchRequest = 9;
- getIsChunk() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
-
Gets the value of the 'isChunk' field.
- getIsDataRecoveryComplete() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
-
Gets the value of the 'isDataRecoveryComplete' field.
- getIsDavinciHeartbeatReported() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getIsDavinciHeartbeatReported() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getIsDavinciHeartbeatReported() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getIsDavinciHeartbeatReported() - Method in interface com.linkedin.venice.meta.Store
- getIsDavinciHeartbeatReported() - Method in class com.linkedin.venice.meta.StoreInfo
- getIsDavinciHeartbeatReported() - Method in class com.linkedin.venice.meta.SystemStore
- getIsDavinciHeartbeatReported() - Method in interface com.linkedin.venice.meta.Version
- getIsDavinciHeartbeatReported() - Method in class com.linkedin.venice.meta.VersionImpl
- getIsDavinciHeartbeatReported() - Method in class com.linkedin.venice.meta.ZKStore
- getIsDaVinciHeartBeatReported() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'isDaVinciHeartBeatReported' field.
- getIsDaVinciHeartBeatReported() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'isDaVinciHeartBeatReported' field.
- getIsDaVinciHeartBeatReported() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'isDaVinciHeartBeatReported' field.
- getIsIncrementalPushEnabled() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'isIncrementalPushEnabled' field.
- getIsLastVersionSwapMessageFromRealTimeTopic() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
-
Gets the value of the 'isLastVersionSwapMessageFromRealTimeTopic' field.
- getIsLatchReleased() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'isLatchReleased' field.
- getIsMigrating() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'isMigrating' field.
- getIsolatedIngestionServiceProcess() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
- getIsPositive() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'isPositive' field.
- getIsReadyLatch() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getIsRegistered() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'isRegistered' field.
- getIsRepush() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
-
Gets the value of the 'isRepush' field.
- getIsRetryRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
bool isRetryRequest = 8;
- getIsRetryRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
bool isRetryRequest = 8;
- getIsRetryRequest() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
bool isRetryRequest = 8;
- getIsStoreDead() - Method in class com.linkedin.venice.meta.StoreInfo
- getIsStreamingRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
bool isStreamingRequest = 7;
- getIsStreamingRequest() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
bool isStreamingRequest = 7;
- getIsStreamingRequest() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
bool isStreamingRequest = 7;
- getIsStreamingResponse() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
bool isStreamingResponse = 5;
- getIsStreamingResponse() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
bool isStreamingResponse = 5;
- getIsStreamingResponse() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
bool isStreamingResponse = 5;
- getIsSystemStore() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional bool isSystemStore = 5;
- getIsSystemStore() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
optional bool isSystemStore = 5;
- getIsSystemStore() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
optional bool isSystemStore = 5;
- getIterator() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
- getIterator() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getIterator(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- getIterator(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getIterator(int) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
- getIterator(int) - Method in interface com.linkedin.davinci.store.StorageEngine
- getJavaMajorVersion() - Static method in class com.linkedin.venice.utils.Utils
- getJdbcIndex() - Method in class com.linkedin.venice.sql.ColumnDefinition
- getJettyConfigOverrides() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getJobClientFromConfig(JobConf) - Method in class com.linkedin.venice.hadoop.mapreduce.engine.DefaultHadoopJobClientProvider
- getJobClientFromConfig(JobConf) - Method in interface com.linkedin.venice.hadoop.mapreduce.engine.HadoopJobClientProvider
- getJobConf() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- getJobDurationInMs() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'jobDurationInMs' field.
- getJobName() - Method in interface com.linkedin.venice.hadoop.engine.EngineTaskConfigProvider
- getJobName() - Method in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
- getJobName() - Method in class com.linkedin.venice.spark.engine.SparkEngineTaskConfigProvider
- getJobProperties() - Method in class com.linkedin.venice.hadoop.VenicePushJob
- getJobProperties() - Method in class com.linkedin.venice.spark.datawriter.jobs.AbstractDataWriterSparkJob
- getJobProps() - Method in interface com.linkedin.venice.hadoop.engine.EngineTaskConfigProvider
- getJobProps() - Method in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
- getJobProps() - Method in class com.linkedin.venice.spark.engine.SparkEngineTaskConfigProvider
- getKafkaBootstrapServer() - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
- getKafkaBootstrapServers() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getKafkaBootstrapServers() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
- getKafkaBootstrapServers() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getKafkaBootstrapServers() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getKafkaBootstrapServers() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
-
Test methods
- getKafkaBootstrapServers(boolean) - Method in interface com.linkedin.venice.controller.Admin
-
Return the ssl or non-ssl bootstrap servers based on the given flag.
- getKafkaBootstrapServers(boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getKafkaBootstrapServers(boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getKafkaBrokerUrl() - Method in class com.linkedin.venice.controllerapi.RepushInfo
- getKafkaBrokerUrl() - Method in class com.linkedin.venice.meta.StoreInfo
- getKafkaClusterAliasToIdMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaClusterIdToAliasMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaClusterIdToUrlMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaClusterMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaClusterUrlResolver() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
-
Used to convert from an alternative Kafka URL to the one used in this server instance.
- getKafkaClusterUrlToAliasMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaClusterUrlToIdMap() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaConsumerConfigsForLocalConsumption() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getKafkaConsumerConfigsForRemoteConsumption() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getKafkaEmptyPollSleepMs() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchMaxSizePerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchMaxTimeMS() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchMinSizePerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchPartitionMaxSizePerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchQuotaBytesPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchQuotaRecordPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchQuotaTimeWindow() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchQuotaUnorderedBytesPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchQuotaUnorderedRecordPerSecond() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaFetchThrottlerFactorsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getKafkaMaxPollRecords() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getKafkaMessageEnvelope(MessageType, boolean, int, boolean, LeaderMetadataWrapper, long) - Method in class com.linkedin.venice.writer.VeniceWriter
-
A utility function to centralize some boiler plate code for the instantiation of
SpecificRecord
classes holding the content of our Kafka values. - getKafkaReadCycleDelayMs() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getKafkaReplicationFactor() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getKafkaReplicationFactorRTTopics() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getKafkaSaslConfig() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getKafkaSaslMechanism() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getKafkaSecurityProtocol() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getKafkaSourceRegion() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getKafkaSSLConfig() - Method in class com.linkedin.venice.SSLConfig
- getKafkaStoreIngestionService() - Method in class com.linkedin.davinci.helix.HelixParticipationService
- getKafkaStoreIngestionService() - Method in class com.linkedin.venice.server.VeniceServer
- getKafkaTopic() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
-
Gets the value of the 'kafkaTopic' field.
- getKafkaTopic() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getKafkaTopic() - Method in class com.linkedin.venice.pushmonitor.KillOfflinePushMessage
- getKafkaTopic() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getKafkaTopic() - Method in class com.linkedin.venice.status.StoreStatusMessage
- getKafKaTopic() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Result
- getKafkaTopicConfigs(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
-
No ACL check; any user is allowed to check topic configs.
- getKafkaTopicConfigs(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getKafkaUrl() - Method in class com.linkedin.davinci.validation.PartitionTracker.TopicType
- getKafkaUrl() - Method in class com.linkedin.venice.hadoop.VenicePushJob
- getKafkaValueSerializer() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getKafkaValueSerializer() - Method in class com.linkedin.venice.controller.VeniceControllerService
- getKafkaValueSerializer(JobConf) - Static method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputUtils
- getKafkaVersionTopic() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getKey() - Method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
- getKey() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
- getKey() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
-
Gets the value of the 'key' field.
- getKey() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
-
Gets the value of the 'key' field.
- getKey() - Method in class com.linkedin.venice.fastclient.GetRequestContext
- getKey() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext.KeyInfo
- getKey() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
-
Gets the value of the 'key' field.
- getKey() - Method in class com.linkedin.venice.message.KafkaKey
- getKey() - Method in interface com.linkedin.venice.pubsub.api.DefaultPubSubMessage
-
Retrieves the key associated with this message.
- getKey() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getKey() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getKey() - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
- getKey() - Method in class com.linkedin.venice.utils.KeyAndValueSchemas
- getKey() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getKey(ProducerMetadata) - Method in interface com.linkedin.venice.writer.VeniceWriter.KeyProvider
- getKeyBuffer() - Method in class com.linkedin.venice.router.api.RouterKey
- getKeyBytes() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getKeyBytes() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
-
Gets the value of the 'keyBytes' field.
- getKeyBytes() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
- getKeyBytes() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
- getKeyBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
used for batch get
- getKeyBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
used for batch get
- getKeyBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
used for batch get
- getKeyBytes() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
-
Gets the value of the 'keyBytes' field.
- getKeyBytes(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
-
Return a serialized output key
- getKeyBytes(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
- getKeyBytesFromUrlKeyString(String) - Static method in class com.linkedin.venice.listener.request.GetRouterRequest
- getKeyClass() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerConfig
- getKeyCount() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
- getKeyCount() - Method in class com.linkedin.venice.listener.request.MultiKeyRouterRequestWrapper
- getKeyCount() - Method in class com.linkedin.venice.listener.request.RouterRequest
- getKeyCount(OptimizedBinaryDecoder) - Method in class com.linkedin.venice.router.RouterThrottleHandler
-
Return number of elements in Avro serialized array of records.
- getKeyCountEstimate() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineStats
- getKeyCountEstimate() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getKeyCountEstimate() - Method in class com.linkedin.davinci.store.StorageEngineNoOpStats
- getKeyCountEstimate() - Method in interface com.linkedin.davinci.store.StorageEngineStats
- getKeyHeaderByte() - Method in enum class com.linkedin.venice.kafka.protocol.enums.MessageType
- getKeyHeaderByte() - Method in class com.linkedin.venice.message.KafkaKey
-
The key header byte is the first byte in the content of the Kafka key.
- getKeyIndex() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
-
Gets the value of the 'keyIndex' field.
- getKeyIndex() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
-
Gets the value of the 'keyIndex' field.
- getKeyIndex() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
-
Gets the value of the 'keyIndex' field.
- getKeyIndex() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
-
Gets the value of the 'keyIndex' field.
- getKeyIndex(ComputeResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
- getKeyIndex(MultiGetResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
- getKeyIndex(ENVELOPE) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
- getKeyLength() - Method in class com.linkedin.venice.message.KafkaKey
- getKeyLevelLockMaxPoolSizeBasedOnServerConfig(VeniceServerConfig, int) - Static method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- getKeyManagerAlgorithm() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getKeyManagers(SSLFactory) - Static method in class com.linkedin.venice.grpc.GrpcUtils
- getKeyName() - Method in exception com.linkedin.venice.exceptions.MissingKeyInStoreMetadataException
- getKeyPassphrase() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getKeyPayloadSerializer() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getKeys() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
- getKeys() - Method in class com.linkedin.venice.listener.request.MultiKeyRouterRequestWrapper
- getKeySchema() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- getKeySchema() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
-
Returns the schema for the key used in
DaVinciClient
's operations. - getKeySchema() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- getKeySchema() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
- getKeySchema() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
- getKeySchema() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
-
Returns Key schema of the store.
- getKeySchema() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getKeySchema() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
-
Deprecated.This method is considered deprecated. Please use
StoreSchemaFetcher.getKeySchema()
to fetch key schema instead. - getKeySchema() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
-
Deprecated.
- getKeySchema() - Method in enum class com.linkedin.venice.common.VeniceSystemStoreType
- getKeySchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
-
Gets the value of the 'keySchema' field.
- getKeySchema() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- getKeySchema() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getKeySchema() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getKeySchema() - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
- getKeySchema() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'keySchema' field.
- getKeySchema() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
string keySchema = 2;
- getKeySchema() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
string keySchema = 2;
- getKeySchema() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
string keySchema = 2;
- getKeySchema() - Method in class com.linkedin.venice.schema.SchemaData
- getKeySchema() - Method in interface com.linkedin.venice.schema.SchemaReader
- getKeySchema() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
- getKeySchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
-
Route to handle retrieving key schema request.
- getKeySchema(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getKeySchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
-
This function is used to retrieve key schema for the given store.
- getKeySchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getKeySchema(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
-
This function is used to retrieve key schema for the given store.
- getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
-
Get key schema for the given store.
- getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getKeySchema(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getKeySchema(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getKeySchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Get key schema for the given store.
- getKeySchema(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getKeySchema(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getKeySchema(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getKeySchemaBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
string keySchema = 2;
- getKeySchemaBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
string keySchema = 2;
- getKeySchemaBytes() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
string keySchema = 2;
- getKeySchemaMap() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
-
Gets the value of the 'keySchemaMap' field.
- getKeySchemaMap() - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
-
Gets the value of the 'keySchemaMap' field.
- getKeySchemaPath() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
- getKeySerializer(Schema) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getKeySerializer(Schema) - Method in class com.linkedin.venice.fastclient.DispatchingVsonStoreClient
-
Deprecated.
- getKeyStoreData() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getKeyStoreData() - Method in class com.linkedin.venice.security.SSLConfig
- getKeyStoreFilePath() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getKeyStoreFilePath() - Method in class com.linkedin.venice.security.SSLConfig
- getKeyStorePassword() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getKeyStorePassword() - Method in class com.linkedin.venice.security.SSLConfig
- getKeyStorePassword() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getKeyStorePath() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getKeyStoreType() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getKeyStoreType() - Method in class com.linkedin.venice.security.SSLConfig
- getKeyStoreType() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getKeyString() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
used for single get
- getKeyString() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
used for single get
- getKeyString() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
used for single get
- getKeyStringBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
used for single get
- getKeyStringBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
used for single get
- getKeyStringBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
used for single get
- getKeyStrings() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
-
Gets the value of the 'keyStrings' field.
- getKeyStrings() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
-
Gets the value of the 'keyStrings' field.
- getKeyStrings() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
-
Gets the value of the 'keyStrings' field.
- getKeysWithChunkIdSuffix() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
-
Gets the value of the 'keysWithChunkIdSuffix' field.
- getKeyType(MessageType, int) - Static method in interface com.linkedin.venice.chunking.ChunkKeyValueTransformer
- getLag() - Method in class com.linkedin.davinci.kafka.consumer.ReplicaHeartbeatInfo
- getLagCaughtUp() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'lagCaughtUp' field.
- getLargeBatchRequestSplitThreshold() - Method in class com.linkedin.davinci.client.DaVinciConfig
- getLargestKnownSchemaId() - Method in class com.linkedin.venice.listener.request.StorePropertiesFetchRequest
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'largestUsedRTVersionNumber' field.
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getLargestUsedRTVersionNumber() - Method in interface com.linkedin.venice.meta.Store
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.meta.StoreInfo
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.meta.SystemStore
- getLargestUsedRTVersionNumber() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.meta.ZKStore
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'largestUsedRTVersionNumber' field.
- getLargestUsedRTVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
-
Gets the value of the 'largestUsedRTVersionNumber' field.
- getLargestUsedRTVersionNumber(String) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
- getLargestUsedRTVersionNumber(String) - Method in interface com.linkedin.venice.meta.StoreGraveyard
-
Retrieve the largest used version number for the real time topic by the given store name from graveyard.
- getLargestUsedVersion(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getLargestUsedVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getLargestUsedVersion(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getLargestUsedVersionFromStoreGraveyard(String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Deprecated.
- getLargestUsedVersionFromStoreGraveyard(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getLargestUsedVersionFromStoreGraveyard(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
-
Gets the value of the 'largestUsedVersionNumber' field.
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'largestUsedVersionNumber' field.
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getLargestUsedVersionNumber() - Method in interface com.linkedin.venice.meta.Store
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.StoreInfo
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.SystemStore
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'largestUsedVersionNumber' field.
- getLargestUsedVersionNumber() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.meta.ZKStore
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'largestUsedVersionNumber' field.
- getLargestUsedVersionNumber() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
-
Gets the value of the 'largestUsedVersionNumber' field.
- getLargestUsedVersionNumber(String) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
- getLargestUsedVersionNumber(String) - Method in interface com.linkedin.venice.meta.StoreGraveyard
-
Retrieve the largest used version number by the given store name from graveyard.
- getLast() - Method in class com.linkedin.alpini.base.misc.DoublyLinkedList
-
Returns the last element in this list.
- getLastCheckPointedSSTFileNum() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
- getLastConsumedVersionTopicOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'lastConsumedVersionTopicOffset' field.
- getLastConsumedVersionTopicPubSubPosition() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'lastConsumedVersionTopicPubSubPosition' field.
- getLastExceptionForStore(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
-
Get the encountered exception during admin message consumption for the given store.
- getLastExecutionId() - Method in class com.linkedin.venice.controller.AdminCommandExecutionTracker
- getLastGeneratedExecutionId(String) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
- getLastGeneratedExecutionId(String) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
-
Get the last id which is generated by execution tracker in the give cluster.
- getLastGeneratedExecutionId(String) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
- getLastIndexOfVersionSeparator(String) - Static method in interface com.linkedin.venice.meta.Version
- getLastKeyJdbcIndex() - Method in class com.linkedin.venice.sql.KeyOnlyPreparedStatementProcessor
- getLastLeaderCompleteStateUpdateInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLastLeaderPersistFuture() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLastNotificationTime() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getLastOffset(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
- getLastOffset(String, int) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
- getLastOffset(String, int) - Method in class com.linkedin.venice.offsets.DeepCopyOffsetManager
- getLastOffset(String, int) - Method in class com.linkedin.venice.offsets.InMemoryOffsetManager
- getLastOffset(String, int) - Method in interface com.linkedin.venice.offsets.OffsetManager
-
Gets the Last Known persisted offset of this consumer.
- getLastProcessedVersionTopicPubSubPosition() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'lastProcessedVersionTopicPubSubPosition' field.
- getLastQueuedRecordPersistedFuture() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLastRecordProducerTimestamp() - Method in class com.linkedin.venice.kafka.validation.Segment
- getLastRecordTimestamp() - Method in class com.linkedin.venice.kafka.validation.Segment
- getLastSucceededExecutionId(String) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
- getLastSucceededExecutionId(String) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
-
Get the id for the last succeed operation in the given cluster.
- getLastSucceededExecutionId(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
-
Get the last succeeded execution id for the given store.
- getLastSucceededExecutionId(String) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
- getLastSucceededExecutionId(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Get last succeeded execution id for a given store; if storeName is null, return the last succeeded execution id for the cluster
- getLastSucceededExecutionIdInCluster(String) - Method in class com.linkedin.venice.controller.kafka.consumer.AdminConsumerService
-
Get the last succeeded execution id for the given cluster.
- getLastSucceededExecutionIdMap(String) - Method in class com.linkedin.venice.admin.InMemoryExecutionIdAccessor
- getLastSucceededExecutionIdMap(String) - Method in interface com.linkedin.venice.controller.ExecutionIdAccessor
-
Get the execution id map that contains the last succeeded operation in the given cluster for each store.
- getLastSucceededExecutionIdMap(String) - Method in class com.linkedin.venice.controller.ZkExecutionIdAccessor
- getLastSucceedExecutionId() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getLastSucceedExecutionId() - Method in class com.linkedin.venice.LastSucceedExecutionIdResponse
- getLastSucceedExecutionId(Admin, ClusterAdminOpsRequestHandler) - Method in class com.linkedin.venice.controller.server.AdminCommandExecutionRoutes
-
No ACL check; any user is allowed to check last succeeded execution Id.
- getLastSucceedExecutionId(LastSuccessfulAdminCommandExecutionGrpcRequest) - Method in class com.linkedin.venice.controller.server.ClusterAdminOpsRequestHandler
- getLastSucceedExecutionId(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get the id of the last succeed execution in this controller.
- getLastSucceedExecutionId(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getLastSucceedExecutionId(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getLastSuccessfulAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse.Builder
-
int64 lastSuccessfulAdminCommandExecutionId = 2;
- getLastSuccessfulAdminCommandExecutionId() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
-
int64 lastSuccessfulAdminCommandExecutionId = 2;
- getLastSuccessfulAdminCommandExecutionId() - Method in interface com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponseOrBuilder
-
int64 lastSuccessfulAdminCommandExecutionId = 2;
- getLastSuccessfulAdminCommandExecutionId(LastSuccessfulAdminCommandExecutionGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceBlockingStub
- getLastSuccessfulAdminCommandExecutionId(LastSuccessfulAdminCommandExecutionGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceFutureStub
- getLastSuccessfulAdminCommandExecutionId(LastSuccessfulAdminCommandExecutionGrpcRequest, StreamObserver<LastSuccessfulAdminCommandExecutionGrpcResponse>) - Method in class com.linkedin.venice.controller.grpc.server.ClusterAdminOpsGrpcServiceImpl
- getLastSuccessfulAdminCommandExecutionId(LastSuccessfulAdminCommandExecutionGrpcRequest, StreamObserver<LastSuccessfulAdminCommandExecutionGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.AsyncService
- getLastSuccessfulAdminCommandExecutionId(LastSuccessfulAdminCommandExecutionGrpcRequest, StreamObserver<LastSuccessfulAdminCommandExecutionGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc.ClusterAdminOpsGrpcServiceStub
- getLastSuccessfulOffset() - Method in class com.linkedin.venice.kafka.validation.Segment
- getLastUpdate() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'lastUpdate' field.
- getLastUpdateTimestamp(Object) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
- getLastVTProduceCallFuture() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestConsumedRtOffset(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestConsumedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
-
Different from the persisted upstream offset map in OffsetRecord, latest consumed upstream offset map is maintained for each individual Kafka url.
- getLatestConsumedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
-
For regular L/F stores without A/A enabled, there is always only one real-time source.
- getLatestConsumedVtOffset() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestConsumedVtOffset() - Method in class com.linkedin.davinci.validation.PartitionTracker
- getLatestConsumedVtOffset() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getLatestCoordinate(Integer) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getLatestCreatedVersion() - Method in class com.linkedin.venice.meta.StoreDataAudit
- getLatestDerivedSchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getLatestDerivedSchema(String, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getLatestDerivedSchema(String, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Get the most recent derived schema added to the given store and value schema id
- getLatestException() - Method in class com.linkedin.venice.utils.ExceptionCaptorNotifier
- getLatestFailedPush() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getLatestIncrementalPushVersion(PartitionAssignment) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getLatestMessageConsumedTimestampInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestMessageConsumptionTimestampInMs() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'latestMessageConsumptionTimestampInMs' field.
- getLatestObservedTermId() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'latestObservedTermId' field.
- getLatestOffset() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- getLatestOffset() - Method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
-
Gets the value of the 'latestOffset' field.
- getLatestOffset(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
-
Returns the latest offset for the given topic-partition.
- getLatestOffset(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
-
Retrieves the latest available offset for a PubSub topic partition.
- getLatestOffsetBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
- getLatestOffsetBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- getLatestOffsetBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
- getLatestOffsetBasedOnMetrics(String, PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
- getLatestOffsetCached(PubSubTopic, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getLatestOffsetCachedNonBlocking(PubSubTopic, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getLatestOffsets(JobConf) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
- getLatestOffsetWithRetries(PubSubTopicPartition, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getLatestPersistedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
-
Returns the latest processed upstream real-time offset for the given region.
- getLatestPersistedUpstreamOffsetForHybridOffsetLagMeasurement(PartitionConsumptionState, String) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
-
For L/F or NR, there is only one entry in upstreamOffsetMap whose key is NON_AA_REPLICATION_UPSTREAM_OFFSET_MAP_KEY.
- getLatestPolledMessageTimestampInMs() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestProcessedLocalVersionTopicOffset() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestProcessedUpstreamRTOffset(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestProcessedUpstreamRTOffsetMap() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestProcessedUpstreamVersionTopicOffset() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLatestProducerProcessingTimeInMs() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getLatestPubSubPosition() - Method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
-
Gets the value of the 'latestPubSubPosition' field.
- getLatestSuccessfulPushVersion() - Method in class com.linkedin.venice.meta.StoreDataAudit
- getLatestSupersetSchemaId() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'latestSuperSetValueSchemaId' field.
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getLatestSuperSetValueSchemaId() - Method in interface com.linkedin.venice.meta.Store
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.StoreInfo
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.SystemStore
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'latestSuperSetValueSchemaId' field.
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.meta.ZKStore
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'latestSuperSetValueSchemaId' field.
- getLatestSuperSetValueSchemaId() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'latestSuperSetValueSchemaId' field.
- getLatestUpdateSchema() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
- getLatestUpdateSchema() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getLatestUpdateSchema() - Method in interface com.linkedin.venice.schema.SchemaReader
- getLatestUpdateSchema() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
- getLatestUpdateSchemaFromSchemaResponse(MultiSchemaResponse, int) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
- getLatestValueSchema() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
-
Deprecated.
- getLatestValueSchema() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
-
Deprecated.
- getLatestValueSchema() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
- getLatestValueSchema() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
- getLatestValueSchema() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
-
Returns the latest available Value schema of the store.
- getLatestValueSchema() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
-
Deprecated.
- getLatestValueSchema() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
-
Deprecated.This method is considered deprecated. Please use
StoreSchemaFetcher.getLatestValueSchemaEntry()
to fetch latest value schema instead. - getLatestValueSchema() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
-
Deprecated.
- getLatestValueSchema() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
-
Deprecated.
- getLatestValueSchema() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
-
Deprecated.
- getLatestValueSchema() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getLatestValueSchema() - Method in interface com.linkedin.venice.schema.SchemaReader
- getLatestValueSchema() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
- getLatestValueSchemaEntry() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
- getLatestValueSchemaEntry() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
- getLatestValueSchemaId() - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
- getLatestValueSchemaId() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getLatestValueSchemaId() - Method in interface com.linkedin.venice.schema.SchemaReader
-
Get the latest value schema id.
- getLatestValueSchemaId() - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
- getLatestVersion() - Static method in class com.linkedin.venice.schema.rmd.RmdSchemaGenerator
- getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getLatestVersionPromoteToCurrentTimestamp() - Method in interface com.linkedin.venice.meta.Store
- getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.SystemStore
- getLatestVersionPromoteToCurrentTimestamp() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
- getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
- getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.meta.ZKStore
- getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'latestVersionPromoteToCurrentTimestamp' field.
- getLatestVersionPromoteToCurrentTimestamp() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
-
Gets the value of the 'latestVersionPromoteToCurrentTimestamp' field.
- getLeaderBytesConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderBytesProduced() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderCompleteState() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLeaderCompleteState(boolean) - Static method in enum class com.linkedin.venice.writer.LeaderCompleteState
- getLeaderCompleteStateCheckInFollowerValidIntervalMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLeaderCompleteStateHeader(LeaderCompleteState) - Static method in class com.linkedin.venice.writer.VeniceWriter
- getLeaderConsumedUpstreamRTOffset(String) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLeaderController() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- getLeaderController() - Method in interface com.linkedin.venice.meta.RoutingDataRepository
-
Query the leader controller of current cluster.
- getLeaderController(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
-
No ACL check; any user is allowed to check leader controller.
- getLeaderController(LeaderControllerGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceBlockingStub
-
ControllerRoutes
- getLeaderController(LeaderControllerGrpcRequest) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceFutureStub
-
ControllerRoutes
- getLeaderController(LeaderControllerGrpcRequest, StreamObserver<LeaderControllerGrpcResponse>) - Method in class com.linkedin.venice.controller.server.VeniceControllerGrpcServiceImpl
- getLeaderController(LeaderControllerGrpcRequest, StreamObserver<LeaderControllerGrpcResponse>) - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.AsyncService
-
ControllerRoutes
- getLeaderController(LeaderControllerGrpcRequest, StreamObserver<LeaderControllerGrpcResponse>) - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc.VeniceControllerGrpcServiceStub
-
ControllerRoutes
- getLeaderController(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get instance of leader controller.
- getLeaderController(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getLeaderController(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getLeaderControllerChangeTimeMs() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- getLeaderControllerChangeTimeMs() - Method in interface com.linkedin.venice.meta.RoutingDataRepository
-
Timestamp in milliseconds of the last time leader controller changed.
- getLeaderControllerDetails(LeaderControllerGrpcRequest) - Method in class com.linkedin.venice.controller.server.VeniceControllerRequestHandler
-
The response is passed as an argument to avoid creating duplicate response objects for HTTP requests and to simplify unit testing with gRPC.
- getLeaderControllerUrl() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getLeaderFollowerHelixStateTransitionThreadPool() - Method in class com.linkedin.davinci.helix.HelixParticipationService
- getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'leaderFollowerModelEnabled' field.
- getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'leaderFollowerModelEnabled' field.
- getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'leaderFollowerModelEnabled' field.
- getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'leaderFollowerModelEnabled' field.
- getLeaderFollowerModelEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'leaderFollowerModelEnabled' field.
- getLeaderFollowerNotifiers() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getLeaderFollowerState() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLeaderFollowerThreadPoolStrategy() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLeaderGUID() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLeaderGUID() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'leaderGUID' field.
- getLeaderGUID() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getLeaderHeartbeatTimeStamps() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- getLeaderHostId() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLeaderHostId() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'leaderHostId' field.
- getLeaderHostId() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getLeaderInstance() - Method in class com.linkedin.venice.meta.Partition
- getLeaderInstance(String, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
-
Used by tests only.
- getLeaderInstance(String, int) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
-
Given resource name and partition number, return the current leader instance.
- getLeaderMetadataFooter() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
-
Gets the value of the 'leaderMetadataFooter' field.
- getLeaderOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'leaderOffset' field.
- getLeaderOffset(String, PubSubTopicRepository) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getLeaderOffset(String, PubSubTopicRepository, boolean) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
-
The caller of this API should be interested in which offset currently leader should consume from now.
- getLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getLeaderOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getLeaderOffsetLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderPreprocessingLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderPreprocessingLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderProducerCompletionLatencySensor() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderProducerFailure() - Method in class com.linkedin.davinci.stats.DIVStats
- getLeaderRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderRecordsProduced() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderSessionIdChecker() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getLeaderStalledHybridIngestion() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLeaderState() - Method in class com.linkedin.davinci.kafka.consumer.ReplicaHeartbeatInfo
- getLeaderState() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'leaderState' field.
- getLeaderTopic() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'leaderTopic' field.
- getLeaderTopic() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getLeaderTopic(PubSubTopicRepository) - Method in class com.linkedin.venice.offsets.OffsetRecord
- getLeakedFutureCleanupPollIntervalMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getLeakedFutureCleanupThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getLeakedPushStatusCleanUpServiceSleepIntervalInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getLeakedResourceAllowedLingerTimeInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getLeakedResourceCleanUpIntervalInMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLength() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
- getLevel() - Method in class com.linkedin.venice.utils.ForkedJavaProcess.LogInfo
- getLevel0FileNumCompactionTrigger() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0FileNumCompactionTriggerForReadWriteLeader() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0FileNumCompactionTriggerWriteOnlyVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0SlowdownWritesTrigger() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0SlowdownWritesTriggerForReadWriteLeader() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0SlowdownWritesTriggerWriteOnlyVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0StopWritesTrigger() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0StopWritesTriggerForReadWriteLeader() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLevel0StopWritesTriggerWriteOnlyVersion() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getLingeringIngestionProcessId(int) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
-
This method returns lingering forked ingestion process PID if it exists.
- getList(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getList(String, List<String>) - Method in class com.linkedin.venice.utils.VeniceProperties
- getListenerHostname() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getListenerPort() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getListWithAlternative(String, String, List<String>) - Method in class com.linkedin.venice.utils.VeniceProperties
- getLiveClusterConfigRepo() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
- getLiveInstanceMonitor(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getLiveRouterInstances() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
- getLiveRouterInstances() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
- getLiveRoutersCount() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
-
Get how many routers live right now.
- getLiveRoutersCount() - Method in interface com.linkedin.venice.meta.RoutersClusterManager
-
Get how many routers are living right now in the cluster.
- getLoadControllerAcceptMultiplier() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLoadControllerAcceptMultiplier() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getLoadControllerComputeLatencyAcceptThresholdMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLoadControllerMaxRejectionRatio() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLoadControllerMaxRejectionRatio() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getLoadControllerMultiGetLatencyAcceptThresholdMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLoadControllerRejectionRatioUpdateIntervalInSec() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLoadControllerRejectionRatioUpdateIntervalInSec() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getLoadControllerSingleGetLatencyAcceptThresholdMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLoadControllerWindowSizeInSec() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLoadControllerWindowSizeInSec() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getLoadedStoreUserPartitionMapping() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionRequestClient
- getLocalAddress() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getLocalAddress() - Method in interface com.linkedin.alpini.router.impl.Router
- getLocalAdminOperationProtocolVersion() - Method in interface com.linkedin.venice.controller.Admin
- getLocalAdminOperationProtocolVersion() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Get the local admin operation protocol version.
- getLocalAdminOperationProtocolVersion() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getLocalAdminOperationProtocolVersion() - Method in class com.linkedin.venice.controllerapi.AdminOperationProtocolVersionControllerResponse
- getLocalAdminOperationProtocolVersion(Admin) - Method in class com.linkedin.venice.controller.server.ControllerRoutes
-
Get the local admin operation protocol version in current controller
- getLocalAdminOperationProtocolVersion(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getLocalBrokerFollowerConsumerLatencySensor() - Method in class com.linkedin.davinci.stats.IngestionStats
- getLocalBrokerTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
- getLocalControllerD2ServiceName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLocalControllerName() - Method in class com.linkedin.venice.controllerapi.AdminOperationProtocolVersionControllerResponse
- getLocalControllerUrl() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLocalD2ZkHost() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getLocalD2ZkHosts() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getLocalHighWatermarkPubSubPositions() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
-
Gets the value of the 'localHighWatermarkPubSubPositions' field.
- getLocalHighWatermarks() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
-
Gets the value of the 'localHighWatermarks' field.
- getLocalRegionName(VeniceProperties, boolean) - Static method in class com.linkedin.venice.utils.RegionUtils
- getLocalStorageEngine(String) - Method in class com.linkedin.davinci.storage.StorageEngineRepository
- getLocalTopicManager() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerRepository
-
By default, return TopicManager for local PubSub cluster.
- getLocalVeniceChangelogConsumerProvider() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getLocalVersionTopicOffset() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getLocation() - Method in interface com.linkedin.alpini.router.api.ResourcePath
- getLocation() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
- getLocation() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
- getLocation() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- getLocations() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
- getLock() - Method in class com.linkedin.davinci.utils.LockAssistedCompletableFuture
- getLockForResource(T) - Method in class com.linkedin.venice.utils.locks.ResourceAutoClosableLockManager
- getLog() - Method in class com.linkedin.venice.logger.TestLogAppender
-
Use this api to verify log messages; once it's called, the log will be cleared.
- getLog() - Method in class com.linkedin.venice.utils.ForkedJavaProcess.LogInfo
- getLogCompactionIntervalMS() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getLogCompactionIntervalMS() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getLogCompactionThreadCount() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getLogCompactionThreadCount() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getLogContext() - Method in interface com.linkedin.venice.controller.Admin
- getLogContext() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getLogContext() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getLogContext() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getLogContext() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getLogger() - Method in class com.linkedin.venice.controller.multitaskscheduler.ScheduledTaskManager
- getLogger() - Method in class com.linkedin.venice.controller.multitaskscheduler.StoreMigrationManager
- getLogicalTimestamp() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
-
Gets the value of the 'logicalTimestamp' field.
- getLogs() - Method in class com.linkedin.venice.utils.InMemoryLogAppender
- getLong(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
- getLong(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getLong(String, long) - Method in class com.linkedin.venice.utils.VeniceProperties
- getLongPointData(Collection<MetricData>, String, String) - Static method in class com.linkedin.venice.utils.OpenTelemetryDataPointTestUtils
- getLongTailMinimumMillis() - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- getLongTailRetryBudgetEnforcementWindowInMs() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getLongTailRetryBudgetEnforcementWindowInMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getLongTailRetryForBatchGetThresholdMs() - Method in interface com.linkedin.venice.router.RouterRetryConfig
- getLongTailRetryForBatchGetThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getLongTailRetryForSingleGetThresholdMs() - Method in interface com.linkedin.venice.router.RouterRetryConfig
- getLongTailRetryForSingleGetThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getLongTailRetryMaxRouteForMultiKeyReq() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getLongTailRetryMaxRouteForMultiKeyReq() - Method in interface com.linkedin.venice.router.RouterRetryConfig
- getLongTailRetryMaxRouteForMultiKeyReq() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getLongTailRetryMilliseconds(P, BasicRequest) - Method in interface com.linkedin.alpini.router.api.LongTailRetrySupplier
- getLongTailRetryMilliseconds(P, BasicRequest) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- getLongTailRetryMilliseconds(P, String) - Method in interface com.linkedin.alpini.router.api.LongTailRetrySupplier
- getLongTailRetryMilliseconds(P, String) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- getLongTailRetryThresholdForBatchGetInMicroSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getLongTailRetryThresholdForComputeInMicroSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getLongTailRetryThresholdForSingleGetInMicroSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getLongTailRetryThresholdMs() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getLongTailRetryThresholdMs() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getLongTailRetryThresholdMs() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- getLowWatermark() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getLowWatermark() - Method in interface com.linkedin.venice.meta.Store
- getLowWatermark() - Method in class com.linkedin.venice.meta.StoreInfo
- getLowWatermark() - Method in class com.linkedin.venice.meta.SystemStore
- getLowWatermark() - Method in class com.linkedin.venice.meta.ZKStore
- getLowWatermark() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'lowWatermark' field.
- getMagicByte() - Method in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
- getMainIngestionMonitorService() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
- getMainIngestionRequestClient() - Method in class com.linkedin.davinci.ingestion.IsolatedIngestionBackend
- getManifest() - Method in class com.linkedin.davinci.storage.chunking.ChunkedValueManifestContainer
- getMap(String) - Method in class com.linkedin.venice.utils.VeniceProperties
-
Retrieves a map from the configuration using the given key, where each entry is a colon-separated string (e.g., "key:value").
- getMap(String, Map<String, String>) - Method in class com.linkedin.venice.utils.VeniceProperties
- getMapperSprayAllPartitionsTriggeredCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getMax() - Method in class com.linkedin.davinci.stats.WritePathLatencySensor
- getMax(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
- getMaxBufferSize() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getMaxBytesPerFile() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
- getMaxCacheSize() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
- getMaxChunkSize() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- getMaxChunkSize() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'maxCompactionLagSeconds' field.
- getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getMaxCompactionLagSeconds() - Method in interface com.linkedin.venice.meta.Store
- getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.StoreInfo
- getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.SystemStore
- getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ZKStore
- getMaxCompactionLagSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'maxCompactionLagSeconds' field.
- getMaxConcurrentSnapshotUser() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getMaxConcurrentSnapshotUser() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getMaxConcurrentSslHandshakes() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMaxConnectionsPerRoute() - Method in class com.linkedin.venice.client.store.ClientConfig
- getMaxConnectionsPerRoute() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
- getMaxConnectionsTotal() - Method in class com.linkedin.venice.client.store.ClientConfig
- getMaxConnectionsTotal() - Method in class com.linkedin.venice.client.store.transport.HttpTransportClient
- getMaxElapsedTimeMSSinceLastPollInConsumerPool() - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
- getMaxElapsedTimeMSSinceLastPollInConsumerPool() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- getMaxElapsedTimeMSSinceLastPollInConsumerPool() - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
- getMaxFileOpeningThreads() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getMaxFollowerHeartbeatLag() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- getMaxFutureVersionLeaderFollowerStateTransitionThreadNumber() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getMaxHeaderSize() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- getMaxHeaderSize() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- getMaxInitialLineLength() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- getMaxInitialLineLength() - Method in class com.linkedin.alpini.netty4.http2.Http2PipelineInitializer.Builder
- getMaxKeyCountInMultiGetReq() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMaxLeaderFollowerStateTransitionThreadNumber() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getMaxLeaderHeartbeatLag() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
- getMaxLogCompactionLagMs() - Method in class com.linkedin.venice.pubsub.PubSubTopicConfiguration
- getMaxLogFileNum() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getMaxLogFileSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getMaxMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
- getMaxMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
- getMaxMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- getMaxMessageTimeInMs() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'maxNearlineRecordSizeBytes' field.
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getMaxNearlineRecordSizeBytes() - Method in interface com.linkedin.venice.meta.Store
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.venice.meta.StoreInfo
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.venice.meta.SystemStore
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.venice.meta.ZKStore
- getMaxNearlineRecordSizeBytes() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'maxNearlineRecordSizeBytes' field.
- getMaxNumberOfPartitions() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMaxNumberUnflushedRecords() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getMaxOpenFiles() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getMaxOutgoingConn() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMaxOutgoingConnPerRoute() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMaxPendingRequest() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMaxRatePerSecond() - Method in class com.linkedin.venice.throttle.EventThrottler
- getMaxReadCapacityCu() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMaxRecordSizeBytes() - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'maxRecordSizeBytes' field.
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getMaxRecordSizeBytes() - Method in interface com.linkedin.venice.meta.Store
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.meta.StoreInfo
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.meta.SystemStore
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.meta.ZKStore
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'maxRecordSizeBytes' field.
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.writer.VeniceWriter
- getMaxRecordSizeBytes() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getMaxRequestSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getMaxRetryAttempts() - Method in class com.linkedin.venice.controller.multitaskscheduler.StoreMigrationManager
- getMaxRouterReadCapacityCu() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMaxSampleSize() - Method in class com.linkedin.venice.hadoop.PushJobZstdConfig
- getMaxSizeForUserPayloadPerMessageInBytes() - Method in class com.linkedin.venice.writer.VeniceWriter
- getMaxValueSchemaId() - Method in class com.linkedin.venice.schema.SchemaData
- getMaxValueSchemaId(String) - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- getMaxWaitAfterUnsubscribeMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getMeasurableProducerMetrics() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
- getMeasurableProducerMetrics() - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
- getMeasurableProducerMetrics() - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterConcurrentDelegator
- getMeasurableProducerMetrics() - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterDelegator
- getMeasurableProducerMetrics() - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
- getMeasurableProducerMetrics() - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
- getMemoryLimit() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getMemoryUsage() - Method in class com.linkedin.venice.utils.collections.MemoryBoundBlockingQueue
- getMemTableHugePageSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getMemtableSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getMergeConflictResult() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
- getMergeConflictResultWrapper() - Method in class com.linkedin.davinci.kafka.consumer.PubSubMessageProcessedResult
- getMergeResultValueSchema(int, int) - Method in class com.linkedin.davinci.replication.merge.MergeResultValueSchemaResolverImpl
-
For general purpose, refer to Javadoc of
MergeResultValueSchemaResolver.getMergeResultValueSchema(int, int)
. - getMessage() - Method in class com.linkedin.davinci.kafka.consumer.PubSubMessageProcessedResultWrapper
- getMessage() - Method in class com.linkedin.davinci.listener.response.AdminResponse
- getMessage() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
- getMessage() - Method in class com.linkedin.davinci.listener.response.ReplicaIngestionResponse
- getMessage() - Method in class com.linkedin.davinci.listener.response.ServerCurrentVersionResponse
- getMessage() - Method in class com.linkedin.davinci.listener.response.StorePropertiesPayload
- getMessage() - Method in enum class com.linkedin.venice.acl.handler.AccessResult
- getMessage() - Method in class com.linkedin.venice.datarecovery.Command.Result
- getMessage() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskResult
- getMessage() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
- getMessage() - Method in exception com.linkedin.venice.exceptions.validation.FatalDataValidationException
- getMessage() - Method in exception com.linkedin.venice.exceptions.VeniceAclException
- getMessage() - Method in exception com.linkedin.venice.exceptions.VeniceHttpException
- getMessage() - Method in exception com.linkedin.venice.exceptions.VeniceMessageException
- getMessage() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'message' field.
- getMessage() - Method in class com.linkedin.venice.listener.response.HttpShortcutResponse
- getMessage(String) - Static method in exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
- getMessageChannel() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getMessageId() - Method in class com.linkedin.venice.status.StatusMessage
-
Get Id of message.
- getMessageSequenceNumber() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
-
Gets the value of the 'messageSequenceNumber' field.
- getMessageSequenceNumber() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'messageSequenceNumber' field.
- getMessageSequenceNumber() - Method in class com.linkedin.venice.storage.protocol.ChunkId
-
Gets the value of the 'messageSequenceNumber' field.
- getMessageTimestamp() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
-
Gets the value of the 'messageTimestamp' field.
- getMessageTimestamp() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'messageTimestamp' field.
- getMessageType() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getMessageType() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
-
Gets the value of the 'messageType' field.
- getMessageType() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
-
Gets the value of the 'messageType' field.
- getMessageType() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
-
Gets the value of the 'messageType' field.
- getMessageType() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
-
Gets the value of the 'messageType' field.
- getMessageUnion() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
-
Gets the value of the 'messageUnion' field.
- getMessagingService() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getMetadata() - Method in class com.linkedin.davinci.blobtransfer.client.P2PMetadataTransferHandler
- getMetadata() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
-
Gets the value of the 'metadata' field.
- getMetadata() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadata() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadata() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadata() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadata() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadata() - Method in interface com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadata(String) - Method in interface com.linkedin.davinci.storage.ReadMetadataRetriever
- getMetadata(String) - Method in class com.linkedin.venice.admin.InMemoryAdminTopicMetadataAccessor
- getMetadata(String) - Method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
-
Retrieve the latest metadata map.
- getMetadata(String) - Method in class com.linkedin.venice.controller.ZkAdminTopicMetadataAccessor
- getMetadata(String) - Method in class com.linkedin.venice.listener.ServerReadMetadataRepository
-
Return the metadata information for the given store.
- getMetadataBuilder() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataClassName() - Method in exception com.linkedin.venice.exceptions.MissingKeyInStoreMetadataException
- getMetadataConnWarmupTimeoutInSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getMetadataMap() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
- getMetadataOrBuilder() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataOrBuilder() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataOrBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataOrBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata metadata = 1;
- getMetadataPartition() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- getMetadataPartition() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
- getMetadataRefreshExecutor() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getMetadataRefreshIntervalInSeconds() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getMetadataRepo() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getMetadataRepo() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getMetadataRepository() - Method in class com.linkedin.venice.router.RouterServer
- getMetadataSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
-
Gets the value of the 'metadataSchema' field.
- getMetadataStalenessHighWatermarkMs() - Method in class com.linkedin.davinci.stats.NativeMetadataRepositoryStats
- getMetadataType() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
-
Gets the value of the 'metadataType' field.
- getMetadataType() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
-
Gets the value of the 'metadataType' field.
- getMetadataUnion() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
-
Gets the value of the 'metadataUnion' field.
- getMetadataUpdateType() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
-
Gets the value of the 'metadataUpdateType' field.
- getMetaStoreName(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
- getMetaStoreReader() - Method in interface com.linkedin.venice.controller.Admin
- getMetaStoreReader() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getMetaStoreReader() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getMetaStoreValue(StoreMetaKey, String) - Method in interface com.linkedin.venice.controller.Admin
- getMetaStoreValue(StoreMetaKey, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getMetaStoreValue(StoreMetaKey, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getMetaStoreWriter() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getMetaStoreWriter() - Method in interface com.linkedin.venice.controller.Admin
-
Return a
MetaStoreWriter
, which can be shared across different Venice clusters. - getMetaStoreWriter() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getMetaStoreWriter() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getMetaStoreWriter() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getMetaStoreWriter(String) - Method in class com.linkedin.venice.system.store.MetaStoreWriter
- getMetaStoreWriterCloseConcurrency() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getMetaStoreWriterCloseConcurrency() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMetaStoreWriterCloseTimeoutInMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getMetaStoreWriterCloseTimeoutInMS() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMethod() - Method in class com.linkedin.venice.authorization.AceEntry
- getMethod() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
string method = 10;
- getMethod() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
string method = 10;
- getMethod() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
string method = 10;
- getMethod() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
- getMethodBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
string method = 10;
- getMethodBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
string method = 10;
- getMethodBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
string method = 10;
- getMethodName() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
-
The request method name
- getMethodName() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
- getMetricConfig(long, long) - Static method in class com.linkedin.venice.utils.metrics.MetricsRepositoryUtils
- getMetricEntities() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getMetricEntity() - Method in enum class com.linkedin.davinci.consumer.stats.BasicConsumerStats.BasicConsumerMetricEntity
- getMetricEntity() - Method in enum class com.linkedin.venice.client.stats.BasicClientStats.BasicClientMetricEntity
- getMetricEntity() - Method in enum class com.linkedin.venice.client.stats.ClientMetricEntity
- getMetricEntity() - Method in enum class com.linkedin.venice.router.stats.RouterMetricEntity
- getMetricEntity() - Method in interface com.linkedin.venice.stats.metrics.ModuleMetricEntityInterface
- getMetricFormat() - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- getMetricFullName(Sensor, MeasurableStat) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
- getMetricName() - Method in enum class com.linkedin.davinci.consumer.stats.BasicConsumerStats.BasicConsumerTehutiMetricName
- getMetricName() - Method in enum class com.linkedin.venice.client.stats.BasicClientStats.BasicClientTehutiMetricName
- getMetricName() - Method in enum class com.linkedin.venice.client.stats.ClientStats.ClientTehutiMetricName
- getMetricName() - Method in enum class com.linkedin.venice.fastclient.stats.FastClientStats.FastClientTehutiMetricName
- getMetricName() - Method in class com.linkedin.venice.stats.metrics.MetricEntity
- getMetricName() - Method in interface com.linkedin.venice.stats.metrics.TehutiMetricNameEnum
- getMetricNamingFormat() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getMetricPrefix() - Method in enum class com.linkedin.venice.read.RequestType
- getMetricPrefix() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getMetricPrefix(String, RequestType) - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
- getMetricsConfig() - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
- getMetricsMap() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getMetricsPrefix() - Method in enum class com.linkedin.venice.stats.ClientType
- getMetricsRepository() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getMetricsRepository() - Method in class com.linkedin.venice.client.store.ClientConfig
- getMetricsRepository() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getMetricsRepository() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getMetricsRepository() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getMetricsRepository() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getMetricsRepository() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterContext
- getMetricsRepository() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getMetricsRepository() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getMetricsRepository() - Method in class com.linkedin.venice.router.RouterServer
- getMetricsRepository() - Method in class com.linkedin.venice.server.VeniceServer
- getMetricsRepository() - Method in class com.linkedin.venice.server.VeniceServerContext
- getMetricsRepository() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
- getMetricsRepository() - Method in interface com.linkedin.venice.tehuti.MetricsAware
- getMetricsRepository(String) - Static method in class com.linkedin.venice.stats.TehutiUtils
-
Get default MetricRepository.
- getMetricType() - Method in class com.linkedin.venice.stats.metrics.MetricEntity
- getMetricValue(String, List<? extends MetricsAware>, DoubleAccumulator) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
- getMetricValues(String, String...) - Method in class com.linkedin.venice.fastclient.stats.ClusterStats
- getMetricValues(String, String...) - Method in class com.linkedin.venice.fastclient.stats.FastClientStats
-
This method is a utility method to get metric values useful in tests and for logging.
- getMigrating() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'migrating' field.
- getMigrating() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'migrating' field.
- getMigrationDestCluster() - Method in class com.linkedin.venice.meta.StoreConfig
- getMigrationDestCluster() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
-
Gets the value of the 'migrationDestCluster' field.
- getMigrationDuplicateStore() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'migrationDuplicateStore' field.
- getMigrationDuplicateStore() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getMigrationDuplicateStore() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'migrationDuplicateStore' field.
- getMigrationPushStrategies() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getMigrationRecord(String) - Method in class com.linkedin.venice.controller.multitaskscheduler.StoreMigrationManager
- getMigrationSrcCluster() - Method in class com.linkedin.venice.meta.StoreConfig
- getMigrationSrcCluster() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
-
Gets the value of the 'migrationSrcCluster' field.
- getMilliseconds() - Method in class com.linkedin.venice.utils.MockCircularTime
- getMilliseconds() - Method in class com.linkedin.venice.utils.SystemTime
- getMilliseconds() - Method in class com.linkedin.venice.utils.TestMockTime
- getMilliseconds() - Method in interface com.linkedin.venice.utils.Time
- getMin(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
- getMinActiveReplicas() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getMinActiveReplicas() - Method in interface com.linkedin.venice.meta.Version
- getMinActiveReplicas() - Method in class com.linkedin.venice.meta.VersionImpl
- getMinBlobSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getMinCompactionLagSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'minCompactionLagSeconds' field.
- getMinCompactionLagSeconds() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getMinCompactionLagSeconds() - Method in interface com.linkedin.venice.meta.Store
- getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.StoreInfo
- getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.SystemStore
- getMinCompactionLagSeconds() - Method in class com.linkedin.venice.meta.ZKStore
- getMinCompactionLagSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'minCompactionLagSeconds' field.
- getMinimalHttpClient(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
- getMinimalHttpClient(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>, boolean, long) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
- getMinimalHttpClient(int, int, Optional<SSLFactory>) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
-
This function is only being used in test cases.
- getMinimalHttpClientWithConnManager(int, int, int, int, int, Optional<SSLFactory>, Optional<CachedDnsResolver>, Optional<HttpConnectionPoolStats>, boolean, long) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
- getMinInSyncReplicas() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinInSyncReplicasAdminTopics() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinInSyncReplicasRealTimeTopics() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
- getMinMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
- getMinMemoryUsagePerDrainer() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- getMinNumberOfPartitions() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinNumberOfPartitionsForHybrid() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinNumberOfStoreVersionsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinNumberOfStoreVersionsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in interface com.linkedin.venice.controller.Admin
- getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getMinNumberOfUnusedKafkaTopicsToPreserve() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getMinSchemaCountToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getMinSchemaCountToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getMissCount() - Method in class com.linkedin.davinci.store.cache.backend.StoreCacheStats
- getMissingMsg() - Method in class com.linkedin.davinci.stats.DIVStats
- getModel(String) - Method in class com.linkedin.venice.controller.VeniceDistClusterControllerStateModelFactory
- getModelList(String, int) - Method in class com.linkedin.venice.utils.MockTestStateModelFactory
- getMonitor() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient
- getMsgRate() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- getMultiClusterConfigFromOneCluster(VeniceControllerClusterConfig) - Static method in class com.linkedin.venice.utils.TestUtils
- getMultiGetResponseRecordDeserializer(int) - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getMultiGetTardyLatencyThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMultiKeyLongTailRetryBudgetPercentDecimal() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMultiKeyRoutingStrategy() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getMutableFabricToExecutionStatusMap() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
Deprecated.
- getName() - Method in enum class com.linkedin.venice.acl.VeniceComponent
- getName() - Method in class com.linkedin.venice.authorization.Principal
- getName() - Method in class com.linkedin.venice.authorization.Resource
- getName() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
-
Gets the value of the 'name' field.
- getName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
-
Gets the value of the 'name' field.
- getName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
-
Gets the value of the 'name' field.
- getName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
-
Gets the value of the 'name' field.
- getName() - Method in class com.linkedin.venice.controllerapi.ControllerResponse
- getName() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
- getName() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getName() - Method in class com.linkedin.venice.meta.ReadOnlyViewStore
- getName() - Method in interface com.linkedin.venice.meta.Store
- getName() - Method in class com.linkedin.venice.meta.StoreInfo
-
Store Name
- getName() - Method in class com.linkedin.venice.meta.StoreName
- getName() - Method in class com.linkedin.venice.meta.StoreVersionName
- getName() - Method in class com.linkedin.venice.meta.SystemStore
- getName() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'name' field.
- getName() - Method in class com.linkedin.venice.meta.ZKStore
- getName() - Method in class com.linkedin.venice.persona.Persona
- getName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapterFactory
- getName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapterFactory
- getName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapterFactory
- getName() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
- getName() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterFactory
- getName() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterFactory
- getName() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterFactory
- getName() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
- getName() - Method in enum class com.linkedin.venice.schema.writecompute.WriteComputeOperation
- getName() - Method in class com.linkedin.venice.service.AbstractVeniceService
- getName() - Method in class com.linkedin.venice.sql.ColumnDefinition
- getName() - Method in class com.linkedin.venice.sql.TableDefinition
- getName() - Method in class com.linkedin.venice.stats.AbstractVeniceStats
- getName() - Method in enum class com.linkedin.venice.stats.ClientType
- getName() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'name' field.
- getNameRepoMaxEntryCount() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getNameValuePairs() - Method in class com.linkedin.venice.controllerapi.QueryParams
- getNanoseconds() - Method in class com.linkedin.venice.utils.MockCircularTime
- getNanoseconds() - Method in class com.linkedin.venice.utils.SystemTime
- getNanoseconds() - Method in class com.linkedin.venice.utils.TestMockTime
- getNanoseconds() - Method in interface com.linkedin.venice.utils.Time
- getNativeReplicationEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'nativeReplicationEnabled' field.
- getNativeReplicationEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'nativeReplicationEnabled' field.
- getNativeReplicationEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'nativeReplicationEnabled' field.
- getNativeReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'nativeReplicationEnabled' field.
- getNativeReplicationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'nativeReplicationEnabled' field.
- getNativeReplicationKafkaBootstrapServerAddress(String) - Method in interface com.linkedin.venice.controller.Admin
- getNativeReplicationKafkaBootstrapServerAddress(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getNativeReplicationKafkaBootstrapServerAddress(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'nativeReplicationSourceFabric' field.
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getNativeReplicationSourceFabric() - Method in interface com.linkedin.venice.meta.Store
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.StoreInfo
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.SystemStore
- getNativeReplicationSourceFabric() - Method in interface com.linkedin.venice.meta.Version
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.VersionImpl
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.meta.ZKStore
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'nativeReplicationSourceFabric' field.
- getNativeReplicationSourceFabric() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'nativeReplicationSourceFabric' field.
- getNativeReplicationSourceFabric(String, Store, Optional<String>, Optional<String>, String) - Method in interface com.linkedin.venice.controller.Admin
- getNativeReplicationSourceFabric(String, Store, Optional<String>, Optional<String>, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
Source fabric selection priority: 1.
- getNativeReplicationSourceFabric(String, Store, Optional<String>, Optional<String>, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getNativeReplicationSourceFabricAsDefaultForBatchOnly() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getNativeReplicationSourceFabricAsDefaultForHybrid() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getNativeReplicationSourceRegion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
-
Gets the value of the 'nativeReplicationSourceRegion' field.
- getNearlineLocalBrokerToReadyToServeLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
- getNearlineLocalBrokerToReadyToServeLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
- getNearlineProducerCompressionEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'nearlineProducerCompressionEnabled' field.
- getNearlineProducerCompressionEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getNearlineProducerCompressionEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'nearlineProducerCompressionEnabled' field.
- getNearlineProducerCountPerWriter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'nearlineProducerCountPerWriter' field.
- getNearlineProducerCountPerWriter() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getNearlineProducerCountPerWriter() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getNearlineProducerCountPerWriter() - Method in interface com.linkedin.venice.meta.Store
- getNearlineProducerCountPerWriter() - Method in class com.linkedin.venice.meta.StoreInfo
- getNearlineProducerCountPerWriter() - Method in class com.linkedin.venice.meta.SystemStore
- getNearlineProducerCountPerWriter() - Method in class com.linkedin.venice.meta.ZKStore
- getNearlineProducerCountPerWriter() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'nearlineProducerCountPerWriter' field.
- getNearlineProducerToLocalBrokerLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
- getNearlineProducerToLocalBrokerLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
- getNettyGracefulShutdownPeriodSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNettyIdleTimeInSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNettyServerToGrpcAddress() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig
- getNettyTimer() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getNettyWorkerThreadCount() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNewIngestionTask(StorageService, Store, Version, Properties, BooleanSupplier, VeniceStoreVersionConfig, int, boolean, Optional<ObjectCacheBackend>, DaVinciRecordTransformerConfig, Lazy<ZKHelixAdmin>) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory
- getNewInstance() - Method in enum class com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
- getNewInstance() - Method in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- getNewInstance() - Method in enum class com.linkedin.venice.kafka.protocol.enums.ControlMessageType
-
Simple utility function to generate the right type of control message, based on message type.
- getNewInstance() - Method in enum class com.linkedin.venice.kafka.protocol.enums.MessageType
-
Simple utility function to generate the right type of payload, based on message type.
- getNewPut() - Method in class com.linkedin.davinci.kafka.consumer.WriteComputeResultWrapper
- getNewResources() - Method in class com.linkedin.venice.helix.ResourceAssignment.ResourceAssignmentChanges
- getNewServingVersionTopic() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
-
Gets the value of the 'newServingVersionTopic' field.
- getNewSourceTopic() - Method in class com.linkedin.davinci.kafka.consumer.TopicSwitchWrapper
- getNewStatsContext() - Method in class com.linkedin.venice.listener.StatsHandler
- getNewValue() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
- getNext() - Method in class com.linkedin.venice.listener.grpc.handlers.VeniceServerGrpcHandler
- getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.AbstractPollStrategy
- getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.ArbitraryOrderingPollStrategy
- getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.BlockingObserverPollStrategy
- getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.CompositePollStrategy
- getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.DuplicatingPollStrategy
- getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.FilteringPollStrategy
- getNextPoll(Map<PubSubTopicPartition, Long>) - Method in class com.linkedin.venice.unit.kafka.consumer.poll.RandomPollStrategy
- getNodeCapacityInRcu() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNodeId() - Method in class com.linkedin.venice.meta.Instance
- getNodeId() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
- getNodeResponsibilityForQuota(PartitionAssignment, String) - Static method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
-
Recalculates the amount of quota that this node should serve given the partition assignment.
- getNodes() - Method in class com.linkedin.venice.controllerapi.MultiNodeResponse
- getNodeState() - Method in class com.linkedin.venice.controllerapi.NodeReplicasReadinessResponse
- getNodeUris() - Method in class com.linkedin.venice.d2.D2Server
- getNodeUris() - Method in class com.linkedin.venice.d2.D2ServerManager
- getNonAvailableReplicaPartitions() - Method in class com.linkedin.venice.fastclient.RequestContext
- getNonCurrentVersionAAWCLeaderQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNonCurrentVersionHeartbeatLag() - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.AggregatedHeartbeatLagEntry
- getNonCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNonExistingKeys() - Method in interface com.linkedin.venice.client.store.streaming.VeniceResponseMap
-
Retrieve all the non-existing keys known so far, and if the current response is a full response, this will contain all the missing keys in the request.
- getNonExistingKeys() - Method in class com.linkedin.venice.client.store.streaming.VeniceResponseMapImpl
- getNonExistingTopicCheckRetryIntervalSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNonExistingTopicIngestionTaskKillThresholdSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNonStoppableInstancesWithReasons() - Method in class com.linkedin.venice.controller.InstanceRemovableStatuses
- getNonStoppableInstancesWithReasons() - Method in class com.linkedin.venice.controllerapi.StoppableNodeStatusResponse
- getNoOpOperation(String) - Method in class com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter
- getNotRepairableSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
- getNow() - Method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
-
Non-blocking variant of
Future.get()
- getNow() - Method in class com.linkedin.alpini.base.concurrency.impl.DefaultAsyncFuture
- getNow() - Method in class com.linkedin.alpini.base.concurrency.impl.FailedAsyncFuture
- getNow() - Method in class com.linkedin.alpini.base.concurrency.impl.SuccessAsyncFuture
- getNullableFieldValueAsList(GenericRecord, Schema.Field) - Static method in class com.linkedin.venice.compute.ComputeUtils
- getNullableStoreStats(String) - Method in class com.linkedin.venice.stats.AbstractVeniceAggStats
- getNumber() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getNumber() - Method in interface com.linkedin.venice.meta.Version
- getNumber() - Method in class com.linkedin.venice.meta.VersionImpl
- getNumber() - Method in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
- getNumber() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'number' field.
- getNumberOfActiveSystemProducers() - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Get the total number of active SystemProducer.
- getNumberOfPartition() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getNumberOfPartitions() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
A function which behaves like
Map.size()
, in the sense that it ignores empty (null) slots in the list. - getNumberOfPartitions() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'numberOfPartitions' field.
- getNumberOfPartitions(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- getNumberOfPartitions(String) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
-
Query number of partition in given kafka topic.
- getNumberOfPartitions(String) - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter
-
Deprecated.
- getNumberOfPartitions(String) - Method in interface com.linkedin.venice.pubsub.api.PubSubProducerAdapter
-
Deprecated.
- getNumberOfPartitions(String) - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterConcurrentDelegator
- getNumberOfPartitions(String) - Method in class com.linkedin.venice.pubsub.api.PubSubProducerAdapterDelegator
- getNumberOfPartitions(String) - Method in class com.linkedin.venice.unit.kafka.producer.MockInMemoryProducerAdapter
- getNumberOfPartitions(String) - Method in class com.linkedin.venice.unit.kafka.producer.TransformingProducerAdapter
- getNumberOfToleratedErrors() - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
- getNumberOfToleratedErrors() - Method in class com.linkedin.venice.pushmonitor.WaitAllPushStatusDecider
- getNumberOfToleratedErrors() - Method in class com.linkedin.venice.pushmonitor.WaitNMinusOnePushStatusDecider
- getNumericOffset() - Method in class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPosition
- getNumericOffset() - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
- getNumericOffset() - Method in class com.linkedin.venice.unit.kafka.InMemoryPubSubPosition
- getNumInputFiles() - Method in class com.linkedin.venice.hadoop.InputDataInfoProvider.InputDataInfo
- getNumOfTotalInstances() - Method in class com.linkedin.venice.meta.Partition
- getNumPartitions(String) - Method in interface com.linkedin.alpini.router.api.AsyncPartitionFinder
-
Returns the number of partitions for a given db
- getNumPartitions(String) - Method in interface com.linkedin.alpini.router.api.PartitionFinder
-
Returns the number of partitions for a given db
- getNumPartitions(String) - Method in class com.linkedin.venice.router.api.VenicePartitionFinder
- getNumSchemaFastClassWarmup() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'numVersionsToPreserve' field.
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getNumVersionsToPreserve() - Method in interface com.linkedin.venice.meta.Store
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.StoreInfo
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.SystemStore
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'numVersionsToPreserve' field.
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.meta.ZKStore
- getNumVersionsToPreserve() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'numVersionsToPreserve' field.
- getObject() - Method in class com.linkedin.venice.samza.VeniceObjectWithTimestamp
- getObjectCache() - Method in class com.linkedin.davinci.DaVinciBackend
- getObjectSchema(Object, Schema) - Static method in class com.linkedin.venice.controller.kafka.protocol.serializer.SemanticDetector
- getObjectSize(Object) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
-
Works for
Measurable
objects and a small number of other types. - getOffLineJobWaitTimeInMilliseconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getOfflinePush(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getOfflinePushAccessor() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getOfflinePushOrThrow(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getOfflinePushOrThrow(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
-
Return a push's status (push status contains the history statuses and current status) and throw exception if it doesn't exist
- getOfflinePushOrThrow(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getOfflinePushStatuesParentPath() - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
- getOfflinePushStatus(String, String) - Method in class com.linkedin.venice.helix.ParentHelixOfflinePushAccessor
- getOffLinePushStatus(String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Query the status of the offline push by given kafka topic.
- getOffLinePushStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getOffLinePushStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Queries child clusters for status.
- getOffLinePushStatus(String, String, Optional<String>, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getOffLinePushStatus(String, String, Optional<String>, String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
- getOffLinePushStatus(String, String, Optional<String>, String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getOffLinePushStatus(String, String, Optional<String>, String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getOfflinePushStatusAccessor() - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
-
For testing only.
- getOfflinePushStatusAndItsPartitionStatuses(String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
- getOfflinePushStatusAndItsPartitionStatuses(String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
-
Read one offline push and its partitions status from persistent storage.
- getOfflinePushStatusCreationTime(String) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
- getOfflinePushStatusCreationTime(String) - Method in interface com.linkedin.venice.pushmonitor.OfflinePushAccessor
-
Get the creation time of the given offline push ZK path; the creation time is set by
System.currentTimeMillis()
. - getOfflinePushStatusForStore(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getOfflinePushStatusForStore(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
- getOfflinePushStatusForStore(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getOfflinePushStrategy() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getOfflinePushStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'offlinePushStrategy' field.
- getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getOffLinePushStrategy() - Method in interface com.linkedin.venice.meta.Store
- getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.SystemStore
- getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'offLinePushStrategy' field.
- getOffLinePushStrategy() - Method in class com.linkedin.venice.meta.ZKStore
- getOfflinePushStrategyFromInt(int) - Static method in enum class com.linkedin.venice.meta.OfflinePushStrategy
- getOfflineRequestCount() - Method in class com.linkedin.alpini.router.api.Scatter
- getOfflineRequests() - Method in class com.linkedin.alpini.router.api.Scatter
- getOffset() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
- getOffset() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
- getOffset() - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
- getOffset() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
-
Gets the value of the 'offset' field.
- getOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
-
Gets the value of the 'offset' field.
- getOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
-
Gets the value of the 'offset' field.
- getOffset() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'offset' field.
- getOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'offset' field.
- getOffset() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 offset = 4;
- getOffset() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
optional int64 offset = 4;
- getOffset() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
optional int64 offset = 4;
- getOffset() - Method in class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPosition
- getOffset() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
- getOffset() - Method in interface com.linkedin.venice.pubsub.api.DefaultPubSubMessage
- getOffset() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getOffset() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
-
The offset of the record in the topic/partition.
- getOffset() - Method in class com.linkedin.venice.status.StoreStatusMessage
- getOffset() - Method in class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
- getOffsetByTime(PubSubTopicPartition, long) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Get offsets for only one partition with a specific timestamp.
- getOffsetLag() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo
- getOffsetLag() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'offsetLag' field.
- getOffsetLag() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getOffsetLag(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- getOffsetLag(PubSubTopicPartition) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
-
Retrieves the consuming offset lag for a PubSub topic partition.
- getOffsetLag(String, int) - Method in class com.linkedin.venice.pubsub.adapter.kafka.TopicPartitionsOffsetsTracker
-
Get consuming offset lag on a topic partition
- getOffsetLagBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
- getOffsetLagBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- getOffsetLagBasedOnMetrics(PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
- getOffsetLagBasedOnMetrics(String, PubSubTopic, PubSubTopicPartition) - Method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
- getOffsetLagDeltaRelaxFactorForFastOnlineTransitionInRestart() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
-
Gets the value of the 'offsetLagThresholdToGoOnline' field.
- getOffsetLagThresholdToGoOnline() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
- getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
-
Gets the value of the 'offsetLagThresholdToGoOnline' field.
- getOffsetLagThresholdToGoOnline() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
-
Gets the value of the 'offsetLagThresholdToGoOnline' field.
- getOffsetRecord() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPartitionMetadata
- getOffsetRecord() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getOffsetRecord() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'offsetRecord' field.
- getOffsetRecord() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'offsetRecord' field.
- getOffsetRecord(long) - Static method in class com.linkedin.venice.utils.TestUtils
- getOffsetRecord(long, boolean) - Static method in class com.linkedin.venice.utils.TestUtils
- getOffsetRecord(long, Optional<Long>) - Static method in class com.linkedin.venice.utils.TestUtils
- getOffsetRegressionDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
- getOffsets() - Method in class com.linkedin.venice.unit.kafka.consumer.MockInMemoryConsumer
- getOffsets(Map<String, Long>) - Static method in class com.linkedin.venice.controller.AdminTopicMetadataAccessor
- getOffsetToOnlineLagThresholdPerPartition(Optional<HybridStoreConfig>, String, int) - Static method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getOldRmdWithValueSchemaId() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
- getOldServingVersionTopic() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
-
Gets the value of the 'oldServingVersionTopic' field.
- getOldValueByteBufferProvider() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
- getOldValueManifest() - Method in class com.linkedin.davinci.kafka.consumer.WriteComputeResultWrapper
- getOldValueManifestContainer() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
- getOldValueProvider() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
- getOngoingIncrementalPushStatusesKey(int) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getOngoingIncrementalPushVersions(Admin) - Method in class com.linkedin.venice.controller.server.JobRoutes
- getOngoingIncrementalPushVersions(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getOngoingIncrementalPushVersions(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
-
Check if there are any ongoing incremental push for the given version topic.
- getOngoingIncrementalPushVersions(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getOngoingIncrementalPushVersions(String, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
-
Get ongoing incremental push versions from the push status store
- getOngoingIncrementalPushVersions(String, PushStatusStoreReader) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
- getOngoingIncrementalPushVersions(String, PushStatusStoreReader) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getOnlineRequestCount() - Method in class com.linkedin.alpini.router.api.Scatter
- getOnlineRequests() - Method in class com.linkedin.alpini.router.api.Scatter
- getOpenTelemetryMetricsRepository() - Method in class com.linkedin.venice.stats.VeniceMetricsRepository
- getOperation() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
-
Gets the value of the 'operation' field.
- getOperation() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
- getOperation() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string operation = 3;
- getOperation() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
string operation = 3;
- getOperation() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
string operation = 3;
- getOperationBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string operation = 3;
- getOperationBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
string operation = 3;
- getOperationBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
string operation = 3;
- getOperationResultFields() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
- getOperationResultFields(List<ComputeOperation>, Schema) - Static method in class com.linkedin.venice.compute.ComputeUtils
- getOperations() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
- getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
-
Gets the value of the 'operations' field.
- getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
-
Gets the value of the 'operations' field.
- getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
-
Gets the value of the 'operations' field.
- getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
-
Gets the value of the 'operations' field.
- getOperations() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
-
Gets the value of the 'operations' field.
- getOperationType() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
-
Gets the value of the 'operationType' field.
- getOperationType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
-
Gets the value of the 'operationType' field.
- getOperator() - Method in enum class com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
- getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
- getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CountOperator
- getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.DotProductOperator
- getOperatorFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.HadamardProductOperator
- getOperatorFieldName(ComputeOperation) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
- getOptimizeDatabaseForBackupVersionNoReadThresholdMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getOptimizeDatabaseServiceScheduleIntervalSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getOptionalArgs() - Method in enum class com.linkedin.venice.Command
- getOptionalExtraDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
-
N.B.: Older versions of the controller did not support these details, so the optional can be empty.
- getOptionalField(Map<String, String>, String) - Static method in class com.linkedin.venice.status.StatusMessage
- getOptionalInt(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getOptionalParameterValue(Request, String) - Static method in class com.linkedin.venice.controller.server.AdminSparkServer
- getOptionalParameterValue(Request, String, String) - Static method in class com.linkedin.venice.controller.server.AdminSparkServer
- getOptionalParams() - Method in enum class com.linkedin.venice.controllerapi.ControllerRoute
- getOptionalStatusDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
-
N.B.: Older versions of the controller did not support these details, so the optional can be empty.
- getOptionalStatusDetails() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getOptions() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getOrDefault(Object, V) - Method in class com.linkedin.davinci.utils.IndexedHashMap
- getOrDefault(String, String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getOriginalChannel(ChannelHandlerContext) - Static method in class com.linkedin.venice.listener.ServerHandlerUtils
-
Return the channel, which contains the ssl handler and it could be the current channel (http/1.x) or the parent channel (http/2).
- getOriginalFuture() - Method in class com.linkedin.venice.utils.concurrent.ChainedCompletableFuture
- getOriginalManager() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getOriginalRequestStartTs() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getOSMemorySize() - Static method in class com.linkedin.venice.utils.Utils
- getOtelAdditionalMetricsReader() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtelAggregationTemporalitySelector() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtelCustomDimensionsMap() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtelEndpoint() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtelExponentialHistogramMaxBuckets() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtelExponentialHistogramMaxScale() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtelExportProtocol() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtelHeaders() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getOtherClusters() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
-
Gets the value of the 'otherClusters' field.
- getOutboundQueueSize() - Method in class com.linkedin.alpini.netty4.ssl.FusedSslHandler
-
The length of the outbound queue.
- getOutboundQueueSizeLimit() - Method in class com.linkedin.alpini.netty4.ssl.FusedSslHandler
- getOutputRecordsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getOutputRecordsCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getOutputRecordsCount() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getOutputRecordsCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getOutputStream() - Method in class com.linkedin.venice.utils.ForkedJavaProcess
- getOutputValueClass() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerConfig
- getOutputValueSchema() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
-
Returns the schema for the output value used in
DaVinciClient
's operations. - getOutputValueSchema() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerConfig
- getOverallExecutionStatus() - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Check whether all the stream reprocessing jobs have succeeded; return false if any of them fail.
- getOverallPushStatus(ExecutionStatus, ExecutionStatus) - Static method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getOverallStatus() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'overallStatus' field.
- getOverloadedInstanceCount() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
- getOwner() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
-
Gets the value of the 'owner' field.
- getOwner() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
-
Gets the value of the 'owner' field.
- getOwner() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'owner' field.
- getOwner() - Method in class com.linkedin.venice.controllerapi.NewStoreResponse
- getOwner() - Method in class com.linkedin.venice.controllerapi.OwnerResponse
- getOwner() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getOwner() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getOwner() - Method in interface com.linkedin.venice.meta.Store
- getOwner() - Method in class com.linkedin.venice.meta.StoreInfo
-
Store Owner
- getOwner() - Method in class com.linkedin.venice.meta.SystemStore
- getOwner() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'owner' field.
- getOwner() - Method in class com.linkedin.venice.meta.ZKStore
- getOwner() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional string owner = 4;
- getOwner() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
optional string owner = 4;
- getOwner() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
optional string owner = 4;
- getOwner() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
-
string owner = 2;
- getOwner() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
-
string owner = 2;
- getOwner() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcResponseOrBuilder
-
string owner = 2;
- getOwner() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'owner' field.
- getOwner() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
-
Returns the thread that currently owns the write lock, or
null
if not owned. - getOwnerBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
optional string owner = 4;
- getOwnerBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
optional string owner = 4;
- getOwnerBytes() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
optional string owner = 4;
- getOwnerBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
-
string owner = 2;
- getOwnerBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
-
string owner = 2;
- getOwnerBytes() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcResponseOrBuilder
-
string owner = 2;
- getOwners() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
-
Gets the value of the 'owners' field.
- getOwners() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
-
Gets the value of the 'owners' field.
- getOwners() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
- getOwners() - Method in class com.linkedin.venice.persona.Persona
- getOwnersAsList() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
- getP2pTransferClientPort() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getP2pTransferServerPort() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getParallelBatchGetChunkSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getParameters() - Method in class com.linkedin.alpini.base.misc.QueryStringDecoder
-
Returns the decoded key-value parameter pairs of the URI.
- getParams() - Method in enum class com.linkedin.venice.controllerapi.ControllerRoute
- getParams() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
- getParams() - Method in class com.linkedin.venice.datarecovery.MonitorCommand
- getParams() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
- getParentControllerMaxErroredTopicNumToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getParentControllerMaxErroredTopicNumToKeep() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getParentControllerRegionState() - Method in interface com.linkedin.venice.controller.Admin
-
Return the state of the region of the parent controller.
- getParentControllerRegionState() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getParentControllerRegionState() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getParentControllerRegionState() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getParentControllerRegionState() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getParentControllerWaitingTimeForConsumptionMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getParentControllerWaitingTimeForConsumptionMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getParentFabrics() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getParentFabrics() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getParentSystemStoreHeartbeatCheckWaitTimeSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getParentSystemStoreRepairCheckIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getParentSystemStoreRepairRetryCount() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getParentUrl() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
- getParentUrl() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- getParserForType() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
- getParserForType() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
- getParticipant(String, String, String, int, String) - Static method in class com.linkedin.venice.utils.TestUtils
-
Deprecated.TODO: migrate to use ServiceFactory for generating a participant
- getParticipant(String, String, String, int, StateModelFactory<StateModel>, String) - Static method in class com.linkedin.venice.utils.TestUtils
- getParticipantId() - Method in class com.linkedin.venice.routerapi.ReplicaState
- getParticipantMessageConsumptionDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getParticipantStoreNameForCluster(String) - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
- getPartition() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- getPartition() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
- getPartition() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- getPartition() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getPartition() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getPartition() - Method in class com.linkedin.davinci.validation.PartitionTracker
- getPartition() - Method in class com.linkedin.venice.kafka.validation.Segment
- getPartition() - Method in class com.linkedin.venice.listener.request.AdminRequest
- getPartition() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
- getPartition() - Method in class com.linkedin.venice.listener.request.HeartbeatRequest
- getPartition() - Method in class com.linkedin.venice.listener.request.TopicPartitionIngestionContextRequest
- getPartition() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
uint32 partition = 1;
- getPartition() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
uint32 partition = 1;
- getPartition() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
uint32 partition = 1;
- getPartition() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
- getPartition() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getPartition() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
-
The partition the record was sent to
- getPartition() - Method in class com.linkedin.venice.routerapi.ReplicaState
- getPartition(byte[]) - Method in class com.linkedin.davinci.VersionBackend
- getPartition(byte[]) - Method in class com.linkedin.venice.writer.VeniceWriter
- getPartition(int) - Method in class com.linkedin.venice.meta.PartitionAssignment
- getPartition(Object) - Method in class com.linkedin.venice.spark.datawriter.partition.VeniceSparkPartitioner
- getPartition(String, int) - Method in class com.linkedin.venice.helix.ResourceAssignment
- getPartition(BytesWritable, int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputMRPartitioner
- getPartition(BytesWritable, int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
- getPartition(BytesWritable, BytesWritable, int) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.partition.VeniceMRPartitioner
- getPartitionAssignment(String) - Method in class com.linkedin.venice.helix.ResourceAssignment
-
TODO: Rename this "getPartitionAssignmentOrThrow", and create an equivalent which returns null when absent.
- getPartitionAssignments(String) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- getPartitionAssignments(String) - Method in interface com.linkedin.venice.meta.RoutingDataRepository
-
Query all partitions allocations that belong to given kafka topic.
- getPartitionConsumptionState() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
- getPartitionConsumptionState(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getPartitionConsumptionStates() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
-
Gets the value of the 'partitionConsumptionStates' field.
- getPartitionCount() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- getPartitionCount() - Method in interface com.linkedin.davinci.client.DaVinciClient
-
Get partition count of a store.
- getPartitionCount() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- getPartitionCount() - Method in interface com.linkedin.davinci.consumer.VeniceChangelogConsumer
- getPartitionCount() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getPartitionCount() - Method in class com.linkedin.davinci.VersionBackend
- getPartitionCount() - Method in class com.linkedin.venice.controllerapi.PartitionResponse
- getPartitionCount() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getPartitionCount() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
- getPartitionCount() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getPartitionCount() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getPartitionCount() - Method in class com.linkedin.venice.meta.ReadOnlyViewStore.ReadOnlyMaterializedViewVersion
- getPartitionCount() - Method in interface com.linkedin.venice.meta.Store
- getPartitionCount() - Method in class com.linkedin.venice.meta.StoreInfo
-
The number of partitions for this store
- getPartitionCount() - Method in class com.linkedin.venice.meta.SystemStore
- getPartitionCount() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'partitionCount' field.
- getPartitionCount() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'partitionCount' field.
- getPartitionCount() - Method in interface com.linkedin.venice.meta.Version
- getPartitionCount() - Method in class com.linkedin.venice.meta.VersionImpl
- getPartitionCount() - Method in class com.linkedin.venice.meta.ZKStore
- getPartitionCount() - Method in class com.linkedin.venice.metadata.response.VersionProperties
-
Gets the value of the 'partitionCount' field.
- getPartitionCount() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'partitionCount' field.
- getPartitionCount() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'partitionCount' field.
- getPartitionCount() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'partitionCount' field.
- getPartitionCount() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getPartitionCount(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Get partition count for a given topic.
- getPartitionCount(String) - Method in class com.linkedin.venice.unit.kafka.InMemoryKafkaBroker
- getPartitionCountRoundUpSize() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPartitionDbName(String, int) - Static method in class com.linkedin.venice.store.rocksdb.RocksDBUtils
- getPartitionDetails() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getPartitionDir() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- getPartitioner() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getPartitionerClass() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
-
Gets the value of the 'partitionerClass' field.
- getPartitionerClass() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getPartitionerClass() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getPartitionerClass() - Method in interface com.linkedin.venice.meta.PartitionerConfig
- getPartitionerClass() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
- getPartitionerClass() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
-
Gets the value of the 'partitionerClass' field.
- getPartitionerClass() - Method in class com.linkedin.venice.metadata.response.VersionProperties
-
Gets the value of the 'partitionerClass' field.
- getPartitionerClass() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
-
Gets the value of the 'partitionerClass' field.
- getPartitionerConfig() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'partitionerConfig' field.
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.ReadOnlyViewStore.ReadOnlyMaterializedViewVersion
- getPartitionerConfig() - Method in interface com.linkedin.venice.meta.Store
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.StoreInfo
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.SystemStore
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'partitionerConfig' field.
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'partitionerConfig' field.
- getPartitionerConfig() - Method in interface com.linkedin.venice.meta.Version
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.VersionImpl
- getPartitionerConfig() - Method in class com.linkedin.venice.meta.ZKStore
- getPartitionerConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'partitionerConfig' field.
- getPartitionerConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'partitionerConfig' field.
- getPartitionerConfig() - Method in class com.linkedin.venice.views.MaterializedView
- getPartitionerParams() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
-
Gets the value of the 'partitionerParams' field.
- getPartitionerParams() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getPartitionerParams() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getPartitionerParams() - Method in interface com.linkedin.venice.meta.PartitionerConfig
- getPartitionerParams() - Method in class com.linkedin.venice.meta.PartitionerConfigImpl
- getPartitionerParams() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
-
Gets the value of the 'partitionerParams' field.
- getPartitionerParams() - Method in class com.linkedin.venice.metadata.response.VersionProperties
-
Gets the value of the 'partitionerParams' field.
- getPartitionerParams() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
-
Gets the value of the 'partitionerParams' field.
- getPartitionerParamsMap(String) - Static method in class com.linkedin.venice.utils.PartitionUtils
- getPartitioners() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getPartitionerType() - Method in class com.linkedin.venice.partitioner.ComplexVenicePartitioner
- getPartitionerType() - Method in class com.linkedin.venice.partitioner.VenicePartitioner
- getPartitionGracefulDropDelaySeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getPartitionId() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPartitionMetadata
- getPartitionId() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
returns the id of this partition
- getPartitionId() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
- getPartitionId() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'partitionId' field.
- getPartitionId() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
-
Gets the value of the 'partitionId' field.
- getPartitionId() - Method in class com.linkedin.venice.fastclient.GetRequestContext
- getPartitionId() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext.KeyInfo
- getPartitionId() - Method in class com.linkedin.venice.helix.Replica
- getPartitionId() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
-
Gets the value of the 'partitionId' field.
- getPartitionId() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
-
Gets the value of the 'partitionId' field.
- getPartitionId() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'partitionId' field.
- getPartitionId() - Method in class com.linkedin.venice.meta.PartitionDetail
- getPartitionId() - Method in class com.linkedin.venice.meta.UncompletedPartition
- getPartitionId() - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
- getPartitionId() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
-
Gets the value of the 'partitionId' field.
- getPartitionId() - Method in class com.linkedin.venice.router.api.RouterKey
- getPartitionId() - Method in class com.linkedin.venice.status.StoreStatusMessage
- getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.ConstantVenicePartitioner
- getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.DefaultVenicePartitioner
- getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.InvalidKeySchemaPartitioner
- getPartitionId(byte[], int) - Method in class com.linkedin.venice.partitioner.VenicePartitioner
-
A function that returns the partitionId based on the key and partition count.
- getPartitionId(byte[], int) - Method in class com.linkedin.venice.unit.kafka.SimplePartitioner
- getPartitionId(byte[], int, int, int) - Method in class com.linkedin.venice.partitioner.DefaultVenicePartitioner
- getPartitionId(byte[], int, int, int) - Method in class com.linkedin.venice.partitioner.VenicePartitioner
-
Implementors of this class can optionally provide an implementation of this function, which would result in eliminating an instantiation of
ByteBuffer
in the case where the provided offset and length do not map to the boundaries of the byte[]. - getPartitionId(byte[], GenericRecord, int) - Method in class com.linkedin.venice.partitioner.ComplexVenicePartitioner
-
A complex partitioner API that could be used in materialized views to partition based on value.
- getPartitionId(int, byte[]) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
- getPartitionId(int, byte[]) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getPartitionId(int, ByteBuffer) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getPartitionId(int, ByteBuffer) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getPartitionId(String) - Static method in class com.linkedin.venice.utils.HelixUtils
- getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.ConstantVenicePartitioner
- getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.DefaultVenicePartitioner
- getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.InvalidKeySchemaPartitioner
- getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.partitioner.VenicePartitioner
- getPartitionId(ByteBuffer, int) - Method in class com.linkedin.venice.unit.kafka.SimplePartitioner
- getPartitionIdFromServerIncrementalPushKey(PushStatusKey) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getPartitionIds() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Get all Partition Ids which are assigned to the current Node.
- getPartitionIds() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getPartitionIds() - Method in interface com.linkedin.davinci.store.StorageEngine
-
Get all Partition Ids which are assigned to the current Node.
- getPartitionIngestionStatus(int) - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
- getPartitionIngestionStatusSet() - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
- getPartitionKey() - Method in interface com.linkedin.alpini.router.api.ResourcePath
- getPartitionKeys() - Method in interface com.linkedin.alpini.router.api.ResourcePath
- getPartitionKeys() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
- getPartitionKeys() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getPartitionListToSubscribe(Set<Integer>, Set<PubSubTopicPartition>, PubSubTopic) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getPartitionName(String, int) - Static method in class com.linkedin.venice.utils.HelixUtils
- getPartitionNameFromVeniceClusterName(String) - Static method in class com.linkedin.venice.controller.VeniceControllerStateModel
-
Get the controller partition name.
- getPartitionNamesToQuery() - Method in class com.linkedin.alpini.router.api.BroadcastScatterGatherRequest
-
For table level query requests, return the list of partitions that should be queried for this request.
- getPartitionNamesToQuery() - Method in class com.linkedin.alpini.router.api.ScatterGatherRequest
-
Only used by broadcast queries.
- getPartitionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
-
Gets the value of the 'partitionNum' field.
- getPartitionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'partitionNum' field.
- getPartitionNumber() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopicPartition
- getPartitionNumber() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
- getPartitionOffset(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Retrieve the offset associated with the partitionId from the metadata partition.
- getPartitionOffset(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getPartitionOffset(int) - Method in interface com.linkedin.davinci.store.StorageEngine
-
Retrieve the offset associated with the partitionId from the metadata partition.
- getPartitionOffsetLagBasedOnMetrics(String, PubSubTopic, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getPartitionOffsetRecords(String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
-
This method should only be called when the forked ingestion process is handing over ingestion task to main process.
- getPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- getPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
- getPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getPartitionOrThrow(int) - Method in interface com.linkedin.davinci.store.StorageEngine
- getPartitionOrVersionStatusAsync(String, int, int, Optional<String>, Optional<String>, boolean) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
-
If it is batch reporting, then only query with version-level key; else query with partition-level key.
- getPartitionQuotaInBytes() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
- getPartitions() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- getPartitions() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getPartitions() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getPartitionSize() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
Get the partition database size in bytes
- getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEnginePartition
- getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.memory.InMemoryStoragePartition
- getPartitionSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getPartitionStates(PartitionTracker.TopicType) - Method in class com.linkedin.davinci.validation.PartitionTracker
- getPartitionStateSerializer() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getPartitionStateSerializer() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getPartitionStatus(int) - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getPartitionStatus(PartitionStatus, int, Map<Instance, HelixState>, DisableReplicaCallback) - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
- getPartitionStatus(String, int) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
-
Get one partition status ZNode from ZK by given topic and partition.
- getPartitionStatus(String, int, int, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getPartitionStatus(String, int, int, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getPartitionStatusAsync(String, int, int, Optional<String>, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getPartitionStatuses() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getPartitionStatuses(String, int) - Method in class com.linkedin.venice.helix.VeniceOfflinePushMonitorAccessor
-
Get all partition status ZNodes under offline push of given topic from ZK.
- getPartitionStatuses(String, int, String, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
-
Return statuses of all replicas belonging to partitions with partitionIds in the range [0 (inclusive), numberOfPartitions (exclusive)) {partitionId: {instance:status, instance:status,...},...}
- getPartitionStatuses(String, int, String, int, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getPartitionStatuses(String, int, String, Set<Integer>, Optional<Integer>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
-
Return statuses of all replicas belonging to partitions mentioned in partitionIds.
- getPartitionWriterCloseCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getPartitionWriterCloseCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getPartitionWriterCloseCount() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getPassword(Credentials, Text) - Method in class com.linkedin.venice.hadoop.ssl.TempFileSSLConfigurator
- getPath() - Method in class com.linkedin.alpini.base.misc.Metrics
- getPath() - Method in class com.linkedin.alpini.base.misc.QueryStringDecoder
-
Returns the decoded path string of the URI.
- getPath() - Method in class com.linkedin.alpini.router.api.Scatter
- getPath() - Method in enum class com.linkedin.venice.controllerapi.ControllerRoute
- getPathFormat() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Delete
- getPathFormat() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Get
- getPathFormat() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Post
- getPathFormat() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Put
- getPathFormat() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
-
The actual format string with "%s" in place of parameters that will be substituted
- getPathForResource(String) - Static method in class com.linkedin.venice.utils.SslUtils
-
This function should be used in test cases only.
- getPathParams() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Delete
- getPathParams() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Get
- getPathParams() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Post
- getPathParams() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Put
- getPathParams() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
- getPathParamsList() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
- getPathParser() - Method in class com.linkedin.alpini.router.api.Scatter
- getPathWithParameters(String[]) - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
-
Similar to
V1Route.getPathWithParameters(Map)
but takes an ordered list of parameters for substitution. - getPathWithParameters(Map<String, String>) - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
-
Generate path with specified parameters substituted into the path.
- getPayload() - Method in class com.linkedin.davinci.listener.response.ReplicaIngestionResponse
- getPayload() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
-
Gets the value of the 'payload' field.
- getPayloadChunks() - Method in class com.linkedin.venice.writer.ChunkedPayloadAndManifest
- getPayloadRecord() - Method in class com.linkedin.davinci.listener.response.StorePropertiesPayload
- getPayloadSize() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
- getPayloadSize() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getPayloadSize() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getPayloadSize() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getPayloadUnion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
-
Gets the value of the 'payloadUnion' field.
- getPayloadUnion() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
-
Gets the value of the 'payloadUnion' field.
- getPCtrlCliWithoutCluster() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
- getPCtrlCliWithoutCluster() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
- getPCtrlCliWithoutCluster() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getPeersConnectivityFreshnessInSeconds() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getPendingHandshakes() - Method in class com.linkedin.alpini.netty4.ssl.SslInitializer
-
Returns the number of handshakes which are currently blocked awaiting a permit.
- getPendingReportIncPushVersionList() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getPendingReportIncPushVersionList() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getPendingReportIncrementalPushVersions() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'pendingReportIncrementalPushVersions' field.
- getPendingRequestCount(String) - Method in class com.linkedin.venice.router.stats.RouteHttpRequestStats
- getPendingRequestCount(String) - Method in class com.linkedin.venice.stats.HttpConnectionPoolStats
- getPendingRequestCounter(String) - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
- getPendingRequestThrottler() - Method in class com.linkedin.venice.router.api.VeniceDispatcher
-
For TEST ONLY
- getPercentileStat(String) - Static method in class com.linkedin.venice.stats.TehutiUtils
-
Generate a histogram stat that emits P50, P95, and P99 values.
- getPercentileStat(String, int, double) - Static method in class com.linkedin.venice.stats.TehutiUtils
-
Generate a histogram stat that emits P50, P95, and P99 values.
- getPercentileStat(String, int, double, double...) - Static method in class com.linkedin.venice.stats.TehutiUtils
- getPercentileStat(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
-
TODO: need to investigate why percentiles with big values (> 10^6) won't show in InGraph.
- getPercentileStatForNetworkLatency(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
-
Generate a histogram stat that emits P50, P77, P90, P95, P99 and P99.9 values.
- getPercentileStatWithAvgAndMax(String, String) - Static method in class com.linkedin.venice.stats.TehutiUtils
- getPerColoPushJobDetailsStatusFromExecutionStatus(ExecutionStatus) - Static method in class com.linkedin.venice.hadoop.VenicePushJob
-
Transform per colo
ExecutionStatus
to per coloPushJobDetailsStatus
- getPermission() - Method in class com.linkedin.venice.authorization.AceEntry
- getPerNodeClientThreadCount() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
- getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
- getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngine
- getPersistedPartitionIds() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
- getPersistedPartitionIds() - Method in interface com.linkedin.davinci.store.StorageEngine
- getPersistedStoreNames() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
- getPersistedStoreNames() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
- getPersistedStoreNames() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getPersistedStoreNames() - Method in class com.linkedin.davinci.store.StorageEngineFactory
-
Retrieve all the stores persisted previously
- getPersistedToDBFuture() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getPersistenceType() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getPersistenceType() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
- getPersistenceType() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
- getPersistenceType() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getPersistenceType() - Method in class com.linkedin.davinci.store.StorageEngineFactory
-
Return the persistence type current factory supports.
- getPersistenceType() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPersistenceType() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getPersistenceType() - Method in interface com.linkedin.venice.meta.Store
- getPersistenceType() - Method in class com.linkedin.venice.meta.SystemStore
- getPersistenceType() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'persistenceType' field.
- getPersistenceType() - Method in class com.linkedin.venice.meta.ZKStore
- getPersistenceType() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'persistenceType' field.
- getPersistenceTypeFromInt(int) - Static method in enum class com.linkedin.venice.meta.PersistenceType
- getPersistStorageEngineConfig() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
- getPersona(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
-
Returns a persona with the given name within the cluster that the repository is located.
- getPersonaAssociatedWithStore(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
- getPersonaAssociatedWithStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getPersonaAssociatedWithStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getPersonaAssociatedWithStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getPersonaContainingStore(String) - Method in class com.linkedin.venice.helix.StoragePersonaRepository
- getPersonaFromZk(String) - Method in class com.linkedin.venice.persona.StoragePersonaAccessor
- getPerStoreRouterQuotaBuffer() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getPid() - Static method in class com.linkedin.venice.utils.Utils
-
Note: this may fail in some JVM implementations.
- getPipelineSupplier() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getPollTimeout() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getPort() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig
- getPort() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
- getPort() - Method in class com.linkedin.venice.meta.Instance
- getPort() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getPos() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
- getPosition() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
- getPosition() - Method in interface com.linkedin.venice.pubsub.api.DefaultPubSubMessage
-
Retrieves the position of this message within the underlying topic-partition.
- getPosition() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getPosition() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getPositionByTimestamp(PubSubTopicPartition, long) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- getPositionByTimestamp(PubSubTopicPartition, long) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
-
Retrieves the offset of the first message with a timestamp greater than or equal to the target timestamp for the specified PubSub topic-partition.
- getPositionByTimestamp(PubSubTopicPartition, long, Duration) - Method in class com.linkedin.venice.pubsub.adapter.kafka.consumer.ApacheKafkaConsumerAdapter
- getPositionByTimestamp(PubSubTopicPartition, long, Duration) - Method in interface com.linkedin.venice.pubsub.api.PubSubConsumerAdapter
-
Retrieves the offset of the first message with a timestamp greater than or equal to the target timestamp for the specified PubSub topic-partition.
- getPositionFromWireFormat(byte[]) - Static method in class com.linkedin.venice.pubsub.PubSubPositionDeserializer
- getPositionFromWireFormat(PubSubPositionWireFormat) - Static method in interface com.linkedin.venice.pubsub.api.PubSubPosition
- getPositionFromWireFormat(PubSubPositionWireFormat) - Static method in class com.linkedin.venice.pubsub.PubSubPositionDeserializer
- getPositionTypeId() - Method in class com.linkedin.venice.pubsub.PubSubPositionFactory
-
Returns the unique position type ID associated with this factory.
- getPositionWireFormat() - Method in class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPosition
-
Returns an Avro-encoded wire format representation of this position, including both the position type ID and the raw Avro-encoded bytes representing the position value.
- getPositionWireFormat() - Method in interface com.linkedin.venice.pubsub.api.PubSubPosition
-
Position wrapper is used to wrap the position type and the position value.
- getPositionWireFormat() - Method in class com.linkedin.venice.unit.kafka.InMemoryPubSubPosition
- getPotentiallyLossyLeaderOffsetRewindCount() - Method in class com.linkedin.davinci.stats.DIVStats
- getPreferredSchemaFilter() - Method in class com.linkedin.venice.client.store.ClientConfig
- getPrefix() - Method in enum class com.linkedin.venice.common.VeniceSystemStoreType
- getPreviousStatuses() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'previousStatuses' field.
- getPreviousStatusesEntry(String) - Method in class com.linkedin.venice.offsets.OffsetRecord
- getPreviousValue() - Method in class com.linkedin.davinci.consumer.ChangeEvent
- getPreviousValue() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
-
Gets the value of the 'previousValue' field.
- getPrimaryKeyColumns() - Method in class com.linkedin.venice.sql.TableDefinition
- getPrincipal() - Method in class com.linkedin.venice.authorization.AceEntry
- getPrincipalId(X509Certificate) - Method in interface com.linkedin.venice.acl.AccessController
-
Get principal Id from client certificate.
- getPrincipalId(X509Certificate) - Method in class com.linkedin.venice.acl.NoOpDynamicAccessController
- getPrincipalId(X509Certificate) - Method in class com.linkedin.venice.controller.server.VeniceControllerAccessManager
- getPrincipalId(Request) - Method in class com.linkedin.venice.controller.server.AbstractRoute
-
Get principal Id from request.
- getProcessedRecordSizeSinceLastSync() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getProcessedRecordSizeSinceLastSync() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
-
Gets the value of the 'processedRecordSizeSinceLastSync' field.
- getProcessedResult() - Method in class com.linkedin.davinci.kafka.consumer.PubSubMessageProcessedResultWrapper
- getProducedPosition() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getProducedTimestampMs() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getProducer(String, String, boolean, String, Config) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
Samza table writer would directly call this function to create venice system producer instead of calling the general
VeniceSystemFactory.getProducer(String, Config, MetricsRegistry)
function. - getProducer(String, Config, MetricsRegistry) - Method in class com.linkedin.venice.samza.VeniceSystemFactory
-
The core function of a
SystemFactory
; most Samza users would specify VeniceSystemFactory in the job config and Samza would invokeSystemFactory.getProducer(String, Config, MetricsRegistry)
to create producers. - getProducerAdapter() - Method in class com.linkedin.venice.writer.VeniceWriter
- getProducerAdapterFactory() - Method in class com.linkedin.venice.pubsub.PubSubClientsFactory
- getProducerCallBackLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
- getProducerConfigs() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'producerConfigs' field.
- getProducerCount() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getProduceResult() - Method in class com.linkedin.venice.pubsub.adapter.PubSubProducerCallbackSimpleImpl
- getProducerGUID() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
-
Gets the value of the 'producerGUID' field.
- getProducerGUID() - Method in class com.linkedin.venice.storage.protocol.ChunkId
-
Gets the value of the 'producerGUID' field.
- getProducerGUID() - Method in class com.linkedin.venice.writer.VeniceWriter
- getProducerLocalBrokerLatencySensor() - Method in class com.linkedin.davinci.stats.IngestionStats
- getProducerMetadata() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
-
Gets the value of the 'producerMetadata' field.
- getProducerName() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getProducerPartitionState(GUID) - Method in class com.linkedin.venice.offsets.OffsetRecord
- getProducerPartitionStateMap() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getProducerProperties() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
- getProducerQueueSize() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getProducerSourceBrokerLatencySensor() - Method in class com.linkedin.davinci.stats.IngestionStats
- getProducerStates() - Method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
-
Gets the value of the 'producerStates' field.
- getProducerStates() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'producerStates' field.
- getProducerThreadCount() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getProducerTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
- getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
-
Gets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
- getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
- getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
-
Gets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
- getProducerTimestampLagThresholdToGoOnlineInSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
-
Gets the value of the 'producerTimestampLagThresholdToGoOnlineInSeconds' field.
- getProducerTimestampOfLastDataMessageCached(PubSubTopicPartition) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getProducerTimestampOfLastDataMessageWithRetries(PubSubTopicPartition, int) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getProduceToTopicFunction(PartitionConsumptionState, byte[], ByteBuffer, ByteBuffer, ChunkedValueManifest, ChunkedValueManifest, int, boolean) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- getProgress() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputRecordReader
- getProgress() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getProgress() - Method in interface com.linkedin.venice.hadoop.task.TaskTracker
-
Get the progress of the task.
- getProgress() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getProperties() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getPropertiesCopy() - Method in class com.linkedin.venice.utils.VeniceProperties
- getPropertiesForControllerConfig() - Static method in class com.linkedin.venice.utils.TestUtils
- getPropertiesList() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getProperty(List<PropertyKey>) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
-
N.B.: The behavior of this function is different from that of
HelixDataAccessor
, which would swallow exceptions and return an empty collection. - getProperty(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- getPropertyDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
- getPropertyDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
- getPropertyStat(PropertyKey) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- getPropertyStats(List<PropertyKey>) - Method in class com.linkedin.venice.helix.SafeHelixDataAccessor
- getProps() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getProps(JobConf) - Static method in class com.linkedin.venice.hadoop.utils.HadoopUtils
- getProtocolVersion() - Method in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
- getProtocolVersionAutoDetectionSleepMS() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPubSubAdminAdapterFactory() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getPubSubAdminConfigPrefix(String) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubBootstrapServers() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
optional string pubSubBootstrapServers = 6;
- getPubSubBootstrapServers() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
optional string pubSubBootstrapServers = 6;
- getPubSubBootstrapServers() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
optional string pubSubBootstrapServers = 6;
- getPubSubBootstrapServersBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
optional string pubSubBootstrapServers = 6;
- getPubSubBootstrapServersBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
optional string pubSubBootstrapServers = 6;
- getPubSubBootstrapServersBytes() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
optional string pubSubBootstrapServers = 6;
- getPubSubBrokerAddress() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterContext
- getPubSubBrokerAddress() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getPubSubBrokerAddress(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubBrokerAddress(Properties) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubBrokerAddressOrFail(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubBrokerAddressOrFail(Properties) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubBrokerAddressWithDefault(VeniceProperties, String) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubClientsFactory() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getPubSubClientsFactory() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPubSubClientsFactory() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getPubSubClientsFactory() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getPubSubClusterAddress() - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getPubSubConsumer(ChangelogClientConfig, String) - Static method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerClientFactory
- getPubSubConsumerAdapterFactory() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getPubSubConsumerAdapterFactory() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getPubSubConsumerConfigPrefix(String) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubConsumerPollRetryBackoffMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getPubSubConsumerPollRetryTimes() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getPubSubConsumerProperties(String, Properties) - Static method in class com.linkedin.venice.DumpAdminMessages
- getPubSubMessageDeserializer() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getPubSubMessageDeserializer() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getPubSubMessageHeaders() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getPubSubMessageHeaders() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getPubSubMessageSerializer() - Method in class com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig
- getPubSubMessageSerializer() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getPubSubMessageTime() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
- getPubSubMessageTime() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getPubSubMessageTime() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getPubSubMessageTime() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getPubsubOffsetApiTimeoutDurationDefaultValue() - Static method in class com.linkedin.venice.pubsub.PubSubConstants
- getPubSubOperationTimeoutMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getPubSubPosition() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
- getPubSubPosition() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
-
The position of the record in the topic/partition.
- getPubSubPositionClassName() - Method in class com.linkedin.venice.pubsub.adapter.kafka.common.ApacheKafkaOffsetPositionFactory
- getPubSubPositionClassName() - Method in class com.linkedin.venice.pubsub.EarliestPositionFactory
- getPubSubPositionClassName() - Method in class com.linkedin.venice.pubsub.LatestPositionFactory
- getPubSubPositionClassName() - Method in class com.linkedin.venice.pubsub.PubSubPositionFactory
-
Returns the fully qualified class name of the
PubSubPosition
implementation handled by this factory. - getPubSubPositionDeserializer() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterContext
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getPubSubPositionTypeRegistry() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getPubSubProducerConfigPrefix(String) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
- getPubSubProperties(String) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getPubSubPropertiesSupplier() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getPubSubSecurityProtocol() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPubSubSecurityProtocol() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterContext
- getPubSubSecurityProtocol() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getPubSubSecurityProtocol() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getPubSubSecurityProtocol(String) - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getPubSubSecurityProtocolOrDefault(VeniceProperties) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
-
TODO: Enforce explicit configuration of the PubSub security protocol in all components.
- getPubSubSecurityProtocolOrDefault(Properties) - Static method in class com.linkedin.venice.pubsub.PubSubUtil
-
Returns the
PubSubSecurityProtocol
configured in the givenProperties
, falling back to PLAINTEXT if no value is found. - getPubSubSSLProperties(String) - Method in interface com.linkedin.venice.controller.Admin
- getPubSubSSLProperties(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getPubSubSSLProperties(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getPubSubTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopicPartition
- getPubSubTopic() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionImpl
- getPubSubTopicPartition() - Method in class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext
- getPubSubTopicPartition() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionForIngestion
- getPubSubTopicPartition() - Method in class com.linkedin.venice.unit.kafka.consumer.poll.PubSubTopicPartitionOffset
- getPubSubTopicRepository() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getPubSubTopicRepository() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getPubSubTopicRepository() - Method in interface com.linkedin.venice.controller.Admin
- getPubSubTopicRepository() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getPubSubTopicRepository() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getPubSubTopicRepository() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getPubSubTopicRepository() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getPubSubTopicRepository() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminConfig
- getPubSubTopicRepository() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getPubSubTopicRepository() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterContext
- getPubSubTopicRepository() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getPubSubTopicRepository() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getPubSubTopicType() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
- getPubSubTopicType() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
- getPubSubTopicType(String) - Static method in enum class com.linkedin.venice.pubsub.api.PubSubTopicType
- getPushEndDateTime() - Method in class com.linkedin.venice.meta.ReplicaDetail
- getPushEndTimestamp() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getPushId() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'pushId' field.
- getPushJobConfigs() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'pushJobConfigs' field.
- getPushJobDetails(PushJobStatusRecordKey) - Method in interface com.linkedin.venice.controller.Admin
- getPushJobDetails(PushJobStatusRecordKey) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getPushJobDetails(PushJobStatusRecordKey) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getPushJobDetailsStoreName() - Static method in class com.linkedin.venice.common.VeniceSystemStoreUtils
- getPushJobId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'pushJobId' field.
- getPushJobId() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getPushJobId() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getPushJobId() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'pushJobId' field.
- getPushJobId() - Method in interface com.linkedin.venice.meta.Version
- getPushJobId() - Method in class com.linkedin.venice.meta.VersionImpl
- getPushJobId() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'pushJobId' field.
- getPushJobLatestCheckpoint() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'pushJobLatestCheckpoint' field.
- getPushJobSetting() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
- getPushJobSetting() - Method in class com.linkedin.venice.hadoop.VenicePushJob
- getPushJobSetting() - Method in class com.linkedin.venice.jobs.DataWriterComputeJob
- getPushJobSetting() - Method in class com.linkedin.venice.spark.datawriter.jobs.AbstractDataWriterSparkJob
- getPushJobStatusStoreClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPushJobStatusStoreClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getPushJobUserErrorCheckpoints() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPushKey(int) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getPushKey(int, int, Optional<String>) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getPushKey(int, int, Optional<String>, Optional<String>) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getPushKey(int, Optional<String>) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getPushMonitor() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getPushProperties() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getPushSSLAllowlist() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPushStartDateTime() - Method in class com.linkedin.venice.meta.ReplicaDetail
- getPushStartTimestamp() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getPushStatus(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getPushStatusAndDetails(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getPushStatusAndDetails(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
- getPushStatusAndDetails(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getPushStatusDecider() - Method in enum class com.linkedin.venice.meta.OfflinePushStrategy
- getPushStatusNotifierList() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
- getPushStatusStoreHeartbeatExpirationTimeInSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getPushStatusStoreReader() - Method in interface com.linkedin.venice.controller.Admin
- getPushStatusStoreReader() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getPushStatusStoreReader() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getPushStatusStoreWriter() - Method in interface com.linkedin.venice.controller.Admin
- getPushStatusStoreWriter() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getPushStatusStoreWriter() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'pushStreamSourceAddress' field.
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'pushStreamSourceAddress' field.
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getPushStreamSourceAddress() - Method in interface com.linkedin.venice.meta.Store
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.StoreInfo
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.SystemStore
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'pushStreamSourceAddress' field.
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'pushStreamSourceAddress' field.
- getPushStreamSourceAddress() - Method in interface com.linkedin.venice.meta.Version
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.VersionImpl
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.meta.ZKStore
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'pushStreamSourceAddress' field.
- getPushStreamSourceAddress() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'pushStreamSourceAddress' field.
- getPushType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'pushType' field.
- getPushType() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getPushType() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getPushType() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'pushType' field.
- getPushType() - Method in interface com.linkedin.venice.meta.Version
- getPushType() - Method in class com.linkedin.venice.meta.VersionImpl
- getPushType() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'pushType' field.
- getPutErrorCount() - Method in class com.linkedin.davinci.stats.DaVinciRecordTransformerStats
- getPutLatencySensor() - Method in class com.linkedin.davinci.stats.DaVinciRecordTransformerStats
- getPutOnlyPartLength() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- getPutValue() - Method in class com.linkedin.venice.kafka.protocol.Put
-
Gets the value of the 'putValue' field.
- getQuery() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
- getQueryParamsToDiscoverCluster(String) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
- getQueue() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
-
Returns the task queue used by this executor.
- getQueuedReaderThreads() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
-
Returns a collection containing threads that may be waiting to acquire the read lock.
- getQueuedThreads() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
-
Returns a collection containing threads that may be waiting to acquire either the read or write lock.
- getQueuedWriterThreads() - Method in class com.linkedin.venice.utils.concurrent.VeniceReentrantReadWriteLock
-
Returns a collection containing threads that may be waiting to acquire the write lock.
- getQuota() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
- getQuota() - Method in class com.linkedin.venice.throttle.EventThrottler
- getQuota() - Method in class com.linkedin.venice.throttle.GuavaRateLimiter
- getQuota() - Method in class com.linkedin.venice.throttle.TokenBucket
- getQuota() - Method in interface com.linkedin.venice.throttle.VeniceRateLimiter
- getQuotaEnforcementCapacityMultiple() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getQuotaEnforcementIntervalInMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getQuotaEnforcer() - Method in class com.linkedin.venice.listener.HttpChannelInitializer
- getQuotaNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
-
Gets the value of the 'quotaNumber' field.
- getQuotaNumber() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
-
Gets the value of the 'quotaNumber' field.
- getQuotaNumber() - Method in class com.linkedin.venice.persona.Persona
- getQuotaStatus() - Method in class com.linkedin.venice.routerapi.HybridStoreQuotaStatusResponse
- getR2Client() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getR2Client() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig
- getR2Client() - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
- getR2Client(ClientTestUtils.FastClientHTTPVariant) - Static method in class com.linkedin.venice.fastclient.utils.ClientTestUtils
- getR2Client(SSLContext) - Static method in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
- getR2Client(SSLContext, int) - Static method in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
- getR2Client(SSLContext, int, long) - Static method in class com.linkedin.venice.fastclient.transport.HttpClient5BasedR2Client
- getRandomBytes(int) - Static method in class com.linkedin.venice.utils.RandomGenUtils
-
Generate an array of random bytes
- getRandomFloat() - Static method in class com.linkedin.venice.utils.RandomGenUtils
- getRandomIntInRange(int, int) - Static method in class com.linkedin.venice.utils.RandomGenUtils
- getRandomIntWithin(int) - Static method in class com.linkedin.venice.utils.RandomGenUtils
-
Return a random integer between 0 and limit (exclusive)
- getRandomStore() - Static method in class com.linkedin.venice.utils.TestUtils
- getRate() - Method in class com.linkedin.venice.stats.LongAdderRateGauge
- getRateConfig() - Method in class com.linkedin.venice.throttle.EventThrottler
- getRateLimiter() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getRaw(String) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
- getRaw(String) - Method in class com.linkedin.venice.client.store.StatTrackingStoreClient
- getRaw(String, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getRaw(String, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- getRaw(String, Optional<ClientStats>, long) - Method in class com.linkedin.venice.client.store.InternalAvroStoreClient
- getRawBytes() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
-
Gets the value of the 'rawBytes' field.
- getRawBytes() - Method in class org.apache.avro.io.OptimizedBinaryDecoder
- getRawKeyBytes() - Method in class com.linkedin.venice.chunking.RawKeyBytesAndChunkedKeySuffix
- getRawPath() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Delete
- getRawPath() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Get
- getRawPath() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Post
- getRawPath() - Method in enum class com.linkedin.venice.controllerapi.routes.V1Put
- getRawPath() - Method in interface com.linkedin.venice.controllerapi.routes.V1Route
-
Path formatted with colons prefixing each path parameter for use in defining the path in SparkJava ex /user/:id
- getRcu(RouterRequest) - Static method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
-
Initially, this is the key count.
- getRCU() - Method in interface com.linkedin.davinci.listener.response.ReadResponse
-
Get the read compute unit (RCU) for this response's request
- getRCU() - Method in class com.linkedin.venice.listener.response.AbstractReadResponse
-
Get the read compute unit (RCU) for this response's request
- getReadCapacity() - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
- getReadCapacity() - Method in interface com.linkedin.venice.router.throttle.RouterThrottler
- getReadComputationEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'readComputationEnabled' field.
- getReadComputationEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getReadComputationEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'readComputationEnabled' field.
- getReadComputationEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'readComputationEnabled' field.
- getReader() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets the reader schema that was validated.
- getReader(String) - Method in class com.linkedin.venice.controller.ParticipantStoreClientsManager
- getReaderSchema() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getReaderSchema() - Method in class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
- getReadOnlyZKSharedSchemaRepository() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
- getReadOnlyZKSharedSchemaRepository() - Method in interface com.linkedin.venice.controller.Admin
-
Return a shared read only schema repository for zk shared stores.
- getReadOnlyZKSharedSchemaRepository() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReadOnlyZKSharedSchemaRepository() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getReadOnlyZKSharedSystemStoreRepository() - Method in interface com.linkedin.venice.controller.Admin
-
Return a shared read only store repository for zk shared stores.
- getReadOnlyZKSharedSystemStoreRepository() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReadOnlyZKSharedSystemStoreRepository() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getReadQuotaInCU() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'readQuotaInCU' field.
- getReadQuotaInCU() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getReadQuotaInCU() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getReadQuotaInCU() - Method in interface com.linkedin.venice.meta.Store
- getReadQuotaInCU() - Method in class com.linkedin.venice.meta.StoreInfo
- getReadQuotaInCU() - Method in class com.linkedin.venice.meta.SystemStore
- getReadQuotaInCU() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'readQuotaInCU' field.
- getReadQuotaInCU() - Method in class com.linkedin.venice.meta.ZKStore
- getReadQuotaInCU() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'readQuotaInCU' field.
- getReadQuotaThrottlingLeaseTimeoutMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getReadResponse() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
- getReadStrategy() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getReadStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getReadStrategy() - Method in interface com.linkedin.venice.meta.Store
- getReadStrategy() - Method in class com.linkedin.venice.meta.SystemStore
- getReadStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'readStrategy' field.
- getReadStrategy() - Method in class com.linkedin.venice.meta.ZKStore
- getReadStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'readStrategy' field.
- getReadStrategyFromInt(int) - Static method in enum class com.linkedin.venice.meta.ReadStrategy
- getReadWriteRegularStoreSchemaRepository() - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getReadWriteStoreRepository() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getReadyToServeFollowerLag(String) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
- getReadyToServeInOffsetRecord() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getReadyToServeInstances() - Method in class com.linkedin.venice.meta.Partition
- getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
-
Get ready to serve instances from local memory.
- getReadyToServeInstances(PartitionAssignment, int) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
-
Look for ready to serve instances on the given partition assignment.
- getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.pushmonitor.PartitionStatusBasedPushMonitor
- getReadyToServeInstances(PartitionAssignment, int) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
- getReadyToServeInstances(PartitionAssignment, int) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getReadyToServeInstances(PartitionStatus, PartitionAssignment, int) - Static method in class com.linkedin.venice.pushmonitor.PushStatusDecider
- getReadyToServeInstances(String, int) - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
-
Get instances from local memory.
- getReadyToServeInstances(String, int) - Method in interface com.linkedin.venice.meta.OnlineInstanceFinder
-
Query instances that belong to given kafka topic and partition.
- getReadyToServeInstances(Map<CharSequence, StoreReplicaStatus>) - Static method in class com.linkedin.venice.pushmonitor.PushStatusDecider
-
Replicas will be considered ready to serve if their status is
ExecutionStatus.COMPLETED
. - getReadyToServeLeaderLag(String) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatStat
- getReadyToServeWithRTLag() - Method in class com.linkedin.davinci.stats.IngestionStats
- getRealTimeDataSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getRealTimeDataSourceKafkaAddress(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getRealTimeProducerState(String, GUID) - Method in class com.linkedin.venice.offsets.OffsetRecord
- getRealTimeTopicName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
-
Gets the value of the 'realTimeTopicName' field.
- getRealTimeTopicName() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getRealTimeTopicName() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
- getRealTimeTopicName() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- getRealTimeTopicName() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
-
Gets the value of the 'realTimeTopicName' field.
- getRealTimeTopicName(Store) - Static method in class com.linkedin.venice.utils.Utils
-
It follows the following order to search for real time topic name, i) current store-version config, ii) store config, iii) other store-version configs, iv) default name
- getRealTimeTopicName(StoreInfo) - Static method in class com.linkedin.venice.utils.Utils
- getRealTimeTopicName(Version) - Static method in class com.linkedin.venice.utils.Utils
- getRealTimeTopicNameFromSeparateRealTimeTopic(String) - Static method in class com.linkedin.venice.utils.Utils
- getRealtimeTopicProducerStates() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'realtimeTopicProducerStates' field.
- getRealTimeTopicSwitcher() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getRealTimeTopicVersioningEnabled() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getReason() - Method in class com.linkedin.venice.controllerapi.ReadyForDataRecoveryResponse
- getReasonPhrase(HRS) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- getReasonPhrase(HttpResponseStatus) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
- getRecordCount() - Method in class com.linkedin.venice.listener.response.stats.AbstractReadResponseStats
- getRecordCount() - Method in class com.linkedin.venice.listener.response.stats.MultiKeyResponseStats
- getRecordCount() - Method in class com.linkedin.venice.listener.response.stats.SingleGetResponseStats
- getRecordDatum(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
- getRecordDatum(AvroWrapper<IndexedRecord>, NullWritable) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroRecordReader
- getRecordFailureMetric() - Method in class com.linkedin.venice.stats.VeniceOpenTelemetryMetricsRepository
-
for testing purposes
- getRecordNumInAllSSTFiles() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBSstFileWriter
- getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.input.kafka.VeniceKafkaInputMapper
- getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.map.VeniceAvroMapper
- getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.map.VeniceVsonMapper
- getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractInputRecordProcessor
-
A method for child classes to setup
AbstractInputRecordProcessor.veniceRecordReader
. - getRecordReader(VeniceProperties) - Method in class com.linkedin.venice.spark.datawriter.recordprocessor.SparkInputRecordProcessor
- getRecordReader(InputSplit, JobConf, Reporter) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
- getRecordReader(InputSplit, JobConf, Reporter, PubSubConsumerAdapter) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
- getRecordsConsumed() - Method in class com.linkedin.davinci.stats.IngestionStats
- getRecordTimestamp(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
- getRecordTimestamp(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.AbstractAvroRecordReader
- getRecordTimestamp(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
- getRecordTimestamp(BytesWritable, BytesWritable) - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonRecordReader
- getRecordTooLargeFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getRecordTooLargeFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getRecordTooLargeFailureCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getRecordTooLargeFailureCount() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getRecordTooLargeFailureCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getRecordTooLargeFailureCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getRecordTransformerClassHash() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'recordTransformerClassHash' field.
- getRecordTransformerClassHash() - Method in class com.linkedin.venice.offsets.OffsetRecord
- getRecordTransformerConfig() - Method in class com.linkedin.davinci.client.DaVinciConfig
- getRecordTransformerConfig() - Method in class com.linkedin.davinci.consumer.BootstrappingVeniceChangelogConsumerDaVinciRecordTransformerImpl
- getRecordTransformerFunction() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerConfig
- getRecordTransformerUtility() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
- getRecordWithFloatArray(Schema, int, int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
- getRecoveryStores() - Method in class com.linkedin.venice.datarecovery.DataRecoveryClient.DataRecoveryParams
- getRedirectUrl() - Method in class com.linkedin.venice.controller.InstanceRemovableStatuses
- getReducerClosedCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getRedundantExceptionFilter() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getRedundantExceptionFilter() - Static method in class com.linkedin.venice.utils.RedundantExceptionFilter
- getReferenceCount() - Method in class com.linkedin.venice.utils.ReferenceCounted
- getReferenceCount(String) - Method in class com.linkedin.venice.utils.SharedObjectFactory
-
Return the current reference count of the object identified by the .
- getReferenceVersionForStreamingWrites(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
- getReferenceVersionForStreamingWrites(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReferenceVersionForStreamingWrites(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getRefillAmount() - Method in class com.linkedin.venice.throttle.TokenBucket
- getRefreshAttemptsForZkReconnect() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getRefreshAttemptsForZkReconnect() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getRefreshAttemptsForZkReconnect() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRefreshIntervalForZkReconnectInMs() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getRefreshIntervalForZkReconnectInMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getRefreshIntervalForZkReconnectInMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRefreshIntervalInSeconds() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getRegion() - Method in class com.linkedin.davinci.kafka.consumer.ReplicaHeartbeatInfo
- getRegionHybridAvgConsumedOffset(int) - Method in class com.linkedin.davinci.stats.IngestionStats
- getRegionHybridBytesConsumed(int) - Method in class com.linkedin.davinci.stats.IngestionStats
- getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getRegionHybridOffsetLag(int) - Method in class com.linkedin.davinci.stats.IngestionStats
- getRegionHybridRecordsConsumed(int) - Method in class com.linkedin.davinci.stats.IngestionStats
- getRegionName() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getRegionName() - Method in interface com.linkedin.venice.controller.Admin
-
Return the region name of this Admin
- getRegionName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getRegionName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getRegionName() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getRegionName() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getRegionName() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getRegionName() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRegionName() - Method in class com.linkedin.venice.utils.LogContext
- getRegionName(PubSubMessage, Int2ObjectMap<String>) - Static method in class com.linkedin.davinci.kafka.consumer.RegionNameUtil
- getRegionNames() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getRegionPushDetails() - Method in class com.linkedin.venice.controllerapi.RegionPushDetailsResponse
- getRegionPushDetails() - Method in class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
- getRegionPushDetails(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getRegionPushDetails(String, boolean) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getRegionPushDetails(String, String, boolean) - Method in interface com.linkedin.venice.controller.Admin
- getRegionPushDetails(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getRegionPushDetails(String, String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
-
Gets the value of the 'regionsFilter' field.
- getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
-
Gets the value of the 'regionsFilter' field.
- getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
-
Gets the value of the 'regionsFilter' field.
- getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
-
Gets the value of the 'regionsFilter' field.
- getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
-
Gets the value of the 'regionsFilter' field.
- getRegionsFilter() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'regionsFilter' field.
- getRegionsFilter() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getRegionSpecificMetricPrefix(String, String) - Static method in class com.linkedin.venice.utils.RegionUtils
- getRegionsWithStaleData() - Method in class com.linkedin.venice.controllerapi.StoreHealthAuditResponse
- getRegularVersionETLEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
-
Gets the value of the 'regularVersionETLEnabled' field.
- getRegularVersionETLEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getRegularVersionETLEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
-
Gets the value of the 'regularVersionETLEnabled' field.
- getRegularVersionETLEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
-
Gets the value of the 'regularVersionETLEnabled' field.
- getRejectionRatio() - Method in class com.linkedin.venice.fastclient.meta.StoreLoadController
- getRejectionRatio() - Method in class com.linkedin.venice.reliability.LoadController
- getRejectionRatio(String) - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
- getRejectionRatio(String) - Method in class com.linkedin.venice.fastclient.meta.InstanceLoadController
- getRemoteIngestionRepairService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getRemoteIngestionRepairSleepInterval() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getRemoveOnCancelPolicy() - Method in class com.linkedin.alpini.base.misc.TimeScheduledThreadPoolExecutor
-
Gets the policy on whether cancelled tasks should be immediately removed from the work queue at time of cancellation.
- getReplica(long, int, int, int, Set<String>) - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
- getReplica(long, int, int, int, Set<String>) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
-
This function is expected to return fully qualified URI, such as: "https://fake.host:8888".
- getReplicaCurrentStatus(List<StatusSnapshot>) - Static method in class com.linkedin.venice.pushmonitor.PushStatusDecider
-
The helper function is used by both controller and router (leader/follower stores); please be cautious when modifying it because it would affect both components.
- getReplicaDetails() - Method in class com.linkedin.venice.meta.PartitionDetail
- getReplicaFollowerHeartbeatLag(PartitionConsumptionState, String, int, boolean) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
-
Get maximum heartbeat lag from local region for a given FOLLOWER replica.
- getReplicaHistoricStatusList(String) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
- getReplicaId() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getReplicaId() - Method in class com.linkedin.davinci.kafka.consumer.ReplicaHeartbeatInfo
- getReplicaId(PubSubTopicPartition) - Static method in class com.linkedin.venice.utils.Utils
-
Standard logging format for TopicPartition
- getReplicaId(PubSubTopic, int) - Static method in class com.linkedin.venice.utils.Utils
- getReplicaId(String, int) - Static method in class com.linkedin.venice.utils.Utils
- getReplicaId(String, int, String) - Static method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- getReplicaLeaderMaxHeartbeatLag(PartitionConsumptionState, String, int, boolean) - Method in class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatMonitoringService
-
Get maximum heartbeat lag from all regions (except separate RT regions) for a given LEADER replica.
- getReplicas() - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
- getReplicas() - Method in class com.linkedin.venice.controllerapi.VersionCreationResponse
- getReplicas(int, int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getReplicas(int, int) - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getReplicas(long, int, List<String>) - Method in class com.linkedin.venice.fastclient.meta.AbstractClientRoutingStrategy
- getReplicas(long, int, List<String>) - Method in class com.linkedin.venice.fastclient.meta.HelixGroupRoutingStrategy
- getReplicas(long, int, List<String>) - Method in class com.linkedin.venice.fastclient.meta.LeastLoadedClientRoutingStrategy
- getReplicas(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getReplicas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReplicas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getReplicasForInstance(RoutingDataRepository, String) - Static method in class com.linkedin.venice.utils.Utils
- getReplicasOfStorageNode(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getReplicasOfStorageNode(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReplicasOfStorageNode(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getReplicaStates() - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
- getReplicaStates(String, int) - Method in class com.linkedin.venice.helix.HelixCustomizedViewOfflinePushRepository
- getReplicaStatus(HelixPartitionState, String, String) - Method in class com.linkedin.venice.helix.HelixPartitionStateAccessor
- getReplicaStatus(String) - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
- getReplicaStatus(String, int) - Method in class com.linkedin.venice.helix.HelixPartitionStatusAccessor
- getReplicaStatuses() - Method in class com.linkedin.venice.pushmonitor.PartitionStatus
- getReplicateAllConfigs() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'replicateAllConfigs' field.
- getReplicateAllConfigs() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getReplicationCheckpointVector() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
-
Gets the value of the 'replicationCheckpointVector' field.
- getReplicationFactor() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'replicationFactor' field.
- getReplicationFactor() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getReplicationFactor() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getReplicationFactor() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getReplicationFactor() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getReplicationFactor() - Method in interface com.linkedin.venice.meta.Store
- getReplicationFactor() - Method in class com.linkedin.venice.meta.StoreInfo
- getReplicationFactor() - Method in class com.linkedin.venice.meta.SystemStore
- getReplicationFactor() - Method in interface com.linkedin.venice.meta.Version
- getReplicationFactor() - Method in class com.linkedin.venice.meta.VersionImpl
- getReplicationFactor() - Method in class com.linkedin.venice.meta.ZKStore
- getReplicationFactor() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getReplicationFactor() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'replicationFactor' field.
- getReplicationFactor() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'replicationFactor' field.
- getReplicationFactor(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getReplicationFactor(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReplicationFactor(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getReplicationMetadata(int, ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- getReplicationMetadata(int, ByteBuffer) - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getReplicationMetadata(int, ByteBuffer) - Method in interface com.linkedin.davinci.store.StorageEngine
- getReplicationMetadata(StorageEngine, int, byte[], boolean, ChunkedValueManifestContainer) - Static method in class com.linkedin.davinci.storage.chunking.SingleGetChunkingAdapter
- getReplicationMetadata(ByteBuffer) - Method in class com.linkedin.davinci.store.AbstractStoragePartition
-
This API retrieves replication metadata from replicationMetadataColumnFamily.
- getReplicationMetadata(ByteBuffer) - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- getReplicationMetadataPayload() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
-
Gets the value of the 'replicationMetadataPayload' field.
- getReplicationMetadataPayload() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
- getReplicationMetadataPayload() - Method in class com.linkedin.venice.kafka.protocol.Delete
-
Gets the value of the 'replicationMetadataPayload' field.
- getReplicationMetadataPayload() - Method in class com.linkedin.venice.kafka.protocol.Put
-
Gets the value of the 'replicationMetadataPayload' field.
- getReplicationMetadataProtocolVersion() - Method in class com.linkedin.venice.schema.rmd.RmdVersionId
- getReplicationMetadataRecord() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
- getReplicationMetadataSchema(int, int) - Method in class com.linkedin.venice.schema.SchemaData
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getReplicationMetadataSchema(String, int, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getReplicationMetadataSchema(String, int, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
- getReplicationMetadataSchema(String, String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getReplicationMetadataSchema(String, String, int, int) - Method in interface com.linkedin.venice.controller.Admin
- getReplicationMetadataSchema(String, String, int, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReplicationMetadataSchema(String, String, int, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getReplicationMetadataSchemaById(String, int) - Method in class com.linkedin.davinci.consumer.ReplicationMetadataSchemaRepository
- getReplicationMetadataSchemas() - Method in class com.linkedin.venice.schema.SchemaData
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getReplicationMetadataSchemas(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getReplicationMetadataSchemas(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
- getReplicationMetadataSchemas(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getReplicationMetadataSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getReplicationMetadataSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getReplicationMetadataVersion() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getReplicationMetadataVersionId() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
-
Gets the value of the 'replicationMetadataVersionId' field.
- getReplicationMetadataVersionId() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
- getReplicationMetadataVersionId() - Method in class com.linkedin.venice.kafka.protocol.Delete
-
Gets the value of the 'replicationMetadataVersionId' field.
- getReplicationMetadataVersionId() - Method in class com.linkedin.venice.kafka.protocol.Put
-
Gets the value of the 'replicationMetadataVersionId' field.
- getReplicationMetadataVersionId() - Method in class com.linkedin.venice.meta.StoreInfo
- getReplicationMetadataVersionID() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'replicationMetadataVersionID' field.
- getReplicationMetadataVersionID() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getReplicationMetadataVersionID() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'replicationMetadataVersionID' field.
- getReporter() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getReportTimestamp() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
-
Gets the value of the 'reportTimestamp' field.
- getReportTimestamp() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'reportTimestamp' field.
- getReportType() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'reportType' field.
- getRepushInfo() - Method in class com.linkedin.venice.controllerapi.RepushInfoResponse
- getRepushInfo(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getRepushInfo(String, String, Optional<String>) - Method in interface com.linkedin.venice.controller.Admin
- getRepushInfo(String, String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getRepushInfo(String, String, Optional<String>) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getRepushInfo(String, Optional<String>) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getRepushOrchestratorClassName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getRepushOrchestratorClassName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getRepushOrchestratorConfigs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getRepushOrchestratorConfigs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getRepushSourceVersion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'repushSourceVersion' field.
- getRepushSourceVersion() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getRepushSourceVersion() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getRepushSourceVersion() - Method in interface com.linkedin.venice.meta.Version
- getRepushSourceVersion() - Method in class com.linkedin.venice.meta.VersionImpl
- getRepushSourceVersion() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'repushSourceVersion' field.
- getRepushTtlFilterCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getRepushTtlFilterCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getRepushTtlFilterCount() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getRepushTtlFilterCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getRepushViability() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
- getRequestContentLength() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
-
The content length of the request body in bytes, as retrieved by the header, or -1 if not known.
- getRequestContentLength() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
- GetRequestContext<K> - Class in com.linkedin.venice.fastclient
- GetRequestContext() - Constructor for class com.linkedin.venice.fastclient.GetRequestContext
- getRequestHeaders() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
-
The request headers.
- getRequestHeaders() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
- getRequestId() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
-
A computed UUID for the request
- getRequestId() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
-
Returns the computed request ID of the packet, which is intended to be reasonably unique.
- getRequestId() - Method in class com.linkedin.venice.fastclient.RequestContext
- getRequestId() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getRequestId() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getRequestKeyCount() - Method in class com.linkedin.venice.listener.ServerStatsContext
- getRequestKeyCount() - Method in exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
- getRequestNanos() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
-
High precision nanotime at which the request was received.
- getRequestNanos() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
-
Returns the nanotime of the first packet of which formed this request object.
- getRequestParts(URI) - Static method in class com.linkedin.venice.request.RequestHelper
-
Parses the '/' separated parts of a request uri.
- getRequestPathByKey(K) - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getRequestRate() - Method in class com.linkedin.venice.client.stats.BasicClientStats
- getRequestSize() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getRequestStartTimeInNS() - Method in class com.linkedin.venice.listener.ServerStatsContext
- getRequestStartTimeInNS() - Method in class com.linkedin.venice.listener.StatsHandler
- getRequestTableFormat() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- getRequestTimeout(Headers) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- getRequestTimestamp() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
-
Timestamp at which the request was received.
- getRequestTimestamp() - Method in class com.linkedin.alpini.netty4.misc.BasicHttpRequest
-
Returns the timestamp of the first packet of which formed this request object.
- getRequestTimestamp(Object) - Static method in interface com.linkedin.alpini.base.misc.BasicRequest
- getRequestType() - Method in class com.linkedin.venice.fastclient.BatchGetRequestContext
- getRequestType() - Method in class com.linkedin.venice.fastclient.ComputeRequestContext
- getRequestType() - Method in class com.linkedin.venice.fastclient.GetRequestContext
- getRequestType() - Method in class com.linkedin.venice.fastclient.RequestContext
- getRequestType() - Method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
- getRequestType() - Method in class com.linkedin.venice.listener.request.GetRouterRequest
- getRequestType() - Method in class com.linkedin.venice.listener.request.MultiGetRouterRequestWrapper
- getRequestType() - Method in class com.linkedin.venice.listener.request.RouterRequest
- getRequestType() - Method in class com.linkedin.venice.listener.ServerStatsContext
- getRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
- getRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
- getRequestType() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- getRequestType() - Method in exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
- getRequestType() - Method in class com.linkedin.venice.stats.AbstractVeniceHttpStats
- getRequired(T) - Static method in class com.linkedin.venice.security.SSLConfig.ConfigHelper
- getRequiredArgs() - Method in enum class com.linkedin.venice.Command
- getRequiredField(Map<String, String>, String) - Static method in class com.linkedin.venice.status.StatusMessage
- getRequiredObject(Object) - Static method in class com.linkedin.venice.security.SSLConfig.ConfigHelper
- getReservedVersion() - Method in class com.linkedin.venice.meta.StoreInfo
-
The highest version number that has been reserved.
- getResolveQueueCapacity() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getResolveThreads() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getResource() - Method in class com.linkedin.venice.authorization.AclBinding
- getResource() - Method in exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
- getResource() - Method in class com.linkedin.venice.helix.Replica
- getResourceAssignment() - Method in class com.linkedin.venice.helix.HelixBaseRoutingRepository
- getResourceAssignment() - Method in interface com.linkedin.venice.meta.RoutingDataRepository
- getResourceName() - Method in interface com.linkedin.alpini.router.api.ResourcePath
- getResourceName() - Method in class com.linkedin.venice.listener.request.DictionaryFetchRequest
- getResourceName() - Method in class com.linkedin.venice.listener.request.RouterRequest
- getResourceName() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
-
Gets the value of the 'resourceName' field.
- getResourceName() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
string resourceName = 5;
- getResourceName() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
string resourceName = 5;
- getResourceName() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
string resourceName = 5;
- getResourceName() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getResourceName() - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
- getResourceName(String) - Static method in class com.linkedin.venice.utils.HelixUtils
- getResourceNameBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest.Builder
-
string resourceName = 5;
- getResourceNameBytes() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
-
string resourceName = 5;
- getResourceNameBytes() - Method in interface com.linkedin.venice.protocols.VeniceClientRequestOrBuilder
-
string resourceName = 5;
- getResources() - Method in class com.linkedin.venice.controller.VeniceControllerStateModel
- getResourceType() - Method in class com.linkedin.venice.router.api.VenicePathParserHelper
- getResponseBody() - Method in class com.linkedin.davinci.listener.response.AdminResponse
- getResponseBody() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
- getResponseBody() - Method in interface com.linkedin.davinci.listener.response.ReadResponse
- getResponseBody() - Method in class com.linkedin.davinci.listener.response.StorePropertiesPayload
- getResponseBody() - Method in class com.linkedin.venice.listener.response.AbstractReadResponse
- getResponseBody() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
-
N.B.: This function is backed by a
Lazy
property. - getResponseBody() - Method in class com.linkedin.venice.listener.response.ParallelMultiKeyResponseWrapper
- getResponseBody() - Method in class com.linkedin.venice.listener.response.SingleGetResponseWrapper
- getResponseCode(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- getResponseCode(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
- getResponseDecompressor() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getResponseHeaders(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- getResponseHeaders(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
- getResponseObserver() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
- getResponseRCU() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
uint32 responseRCU = 4;
- getResponseRCU() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
uint32 responseRCU = 4;
- getResponseRCU() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
uint32 responseRCU = 4;
- getResponseReadable(HR) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- getResponseReadable(FullHttpResponse) - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler4
- getResponseRecord() - Method in class com.linkedin.davinci.listener.response.AdminResponse
- getResponseRecord() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
- getResponseSchemaIdHeader() - Static method in class com.linkedin.davinci.listener.response.AdminResponse
- getResponseSchemaIdHeader() - Method in class com.linkedin.davinci.listener.response.MetadataResponse
- getResponseSchemaIdHeader() - Method in interface com.linkedin.davinci.listener.response.ReadResponse
- getResponseSchemaIdHeader() - Method in class com.linkedin.davinci.listener.response.StorePropertiesPayload
- getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.AbstractReadResponse
- getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.ComputeResponseWrapper
- getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.MultiGetResponseWrapper
- getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
- getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.ParallelMultiKeyResponseWrapper
- getResponseSchemaIdHeader() - Method in class com.linkedin.venice.listener.response.SingleGetResponseWrapper
- getResponseStatus() - Method in class com.linkedin.venice.listener.ServerStatsContext
- getResponseStatus(Throwable) - Method in class com.linkedin.alpini.netty4.handlers.AsyncFullHttpRequestHandler
- getRestServiceStorageThreadNum() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getResult() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerResult
- getResult() - Method in class com.linkedin.venice.datarecovery.Command
- getResult() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand
- getResult() - Method in class com.linkedin.venice.datarecovery.meta.RepushViabilityInfo
- getResult() - Method in class com.linkedin.venice.datarecovery.MonitorCommand
- getResult() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
- getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
-
Gets the value of the 'resultFieldName' field.
- getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.Count
-
Gets the value of the 'resultFieldName' field.
- getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
-
Gets the value of the 'resultFieldName' field.
- getResultFieldName() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
-
Gets the value of the 'resultFieldName' field.
- getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CosineSimilarityOperator
- getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.CountOperator
- getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.DotProductOperator
- getResultFieldName(ComputeOperation) - Method in class com.linkedin.venice.compute.HadamardProductOperator
- getResultFieldName(ComputeOperation) - Method in interface com.linkedin.venice.compute.ReadComputeOperator
- getResultFuture() - Method in class com.linkedin.venice.fastclient.RequestContext
- getResultFuture() - Method in class com.linkedin.venice.utils.concurrent.ChainedCompletableFuture
- getResultSchema() - Method in class com.linkedin.venice.client.store.AbstractAvroComputeRequestBuilder
- getResultSchema() - Method in class com.linkedin.venice.client.store.AvroComputeRequestBuilderV3
- getResultSchemaStr() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
- getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
-
Gets the value of the 'resultSchemaStr' field.
- getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
-
Gets the value of the 'resultSchemaStr' field.
- getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
-
Gets the value of the 'resultSchemaStr' field.
- getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
-
Gets the value of the 'resultSchemaStr' field.
- getResultSchemaStr() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
-
Gets the value of the 'resultSchemaStr' field.
- getRetentionTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getRetentionTime() - Method in interface com.linkedin.venice.meta.Store
- getRetentionTime() - Method in class com.linkedin.venice.meta.SystemStore
- getRetentionTime() - Method in class com.linkedin.venice.meta.ZKStore
-
Get the retention time for the RT Topic.
- getRetriableExceptions() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
- getRetriableExceptions() - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- getRetryBackOffInMs() - Method in class com.linkedin.venice.client.store.ClientConfig
- getRetryBudgetPercentage() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getRetryCount() - Method in class com.linkedin.venice.client.store.ClientConfig
- getRetryExecutor() - Method in class com.linkedin.venice.client.store.ClientConfig
- getRetryManagerCorePoolSize() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRetryTokenBucket() - Method in class com.linkedin.venice.meta.RetryManager
- getRewindStartTimestamp() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
-
Gets the value of the 'rewindStartTimestamp' field.
- getRewindTimeInSeconds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
-
Gets the value of the 'rewindTimeInSeconds' field.
- getRewindTimeInSeconds() - Method in interface com.linkedin.venice.meta.HybridStoreConfig
- getRewindTimeInSeconds() - Method in class com.linkedin.venice.meta.HybridStoreConfigImpl
- getRewindTimeInSeconds() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
-
Gets the value of the 'rewindTimeInSeconds' field.
- getRewindTimeInSeconds() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
-
Gets the value of the 'rewindTimeInSeconds' field.
- getRewindTimeInSecondsOverride() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'rewindTimeInSecondsOverride' field.
- getRewindTimeInSecondsOverride() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getRmd() - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
- getRmdByteUsage() - Method in class com.linkedin.davinci.store.AbstractStoragePartition
- getRmdByteUsage() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- getRmdByteUsage() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getRmdChunkingEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'rmdChunkingEnabled' field.
- getRmdChunkingEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getRmdChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'rmdChunkingEnabled' field.
- getRmdChunkingEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'rmdChunkingEnabled' field.
- getRmdManifest() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
- getRmdManifest() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
- getRmdPayload() - Method in class com.linkedin.venice.writer.DeleteMetadata
- getRmdPayload() - Method in class com.linkedin.venice.writer.PutMetadata
- getRmdPayload(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
- getRmdPayload(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
- getRmdPayload(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
- getRmdProtocolId(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
- getRmdProtocolId(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
- getRmdProtocolId(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
- getRmdProtocolVersionId() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
- getRmdRecord() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
- getRmdRecord() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
- getRmdSchema(int) - Method in class com.linkedin.davinci.replication.merge.RmdSerDe
- getRmdSchema(int, int) - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
-
Retrieve RMD schema and annotate map field and string array field's deleted elements list field.
- getRmdSchemaPath() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
- getRmdSerDe() - Method in class com.linkedin.davinci.kafka.consumer.ActiveActiveStoreIngestionTask
- getRMDSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineStats
- getRMDSizeInBytes() - Method in class com.linkedin.davinci.store.StorageEngineNoOpStats
- getRMDSizeInBytes() - Method in interface com.linkedin.davinci.store.StorageEngineStats
- getRmdTimestampType(Object) - Static method in class com.linkedin.venice.schema.rmd.RmdUtils
-
Returns the type of union record given tsObject is.
- getRmdValueSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
- getRmdVersion() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getRmdVersion() - Method in interface com.linkedin.venice.meta.Store
- getRmdVersion() - Method in class com.linkedin.venice.meta.SystemStore
- getRmdVersion() - Method in class com.linkedin.venice.meta.ZKStore
- getRmdVersionId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
- getRmdVersionId() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getRmdVersionId() - Method in interface com.linkedin.venice.meta.Version
- getRmdVersionId() - Method in class com.linkedin.venice.meta.VersionImpl
- getRmdVersionId() - Method in class com.linkedin.venice.writer.DeleteMetadata
- getRmdVersionId() - Method in class com.linkedin.venice.writer.PutMetadata
- getRocksDBAggregatedStatistics() - Method in class com.linkedin.davinci.storage.StorageService
- getRocksDBBlockCacheImplementation() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksdbBlockCacheMemoryLimit() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBBlockCacheShardBits() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBBlockCacheSizeInBytes() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getRocksDBBlockCacheSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBBlockCacheStrictCapacityLimit() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBBloomBitsPerKey() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBBytesPerSync() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBEnvCompactionPoolSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBEnvFlushPoolSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBHugePageTlbSize() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBMaxBytesForLevelBase() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBMaxMemtableCount() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBMaxTotalWalSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBMemtableSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBMinWriteBufferNumberToMerge() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBOptionsCompactionStyle() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBOptionsCompressionType() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBPath() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getRocksDBPath(String, int) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getRocksDBRMDBlockCacheSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBServerConfig() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getRocksDBSSTFileBlockSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBSstFileWriter() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- getRocksDBSstFileWriter() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getRocksDBStatValue(String) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getRocksDBTotalMemtableUsageCapInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRocksDBUseDirectReads() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getRole() - Method in class com.linkedin.alpini.router.api.Scatter
- getRootStatus() - Method in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
- getRoute() - Static method in class com.linkedin.venice.controller.server.NotImplemented
- getRouteHttpRequestStats() - Method in class com.linkedin.venice.router.api.VeniceDispatcher
-
For TEST ONLY
- getRouteId() - Method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
- getRouterAccessController() - Method in class com.linkedin.venice.server.VeniceServerContext
- getRouterClientConfig() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getRouterConnectionWarmingDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getRouterDictionaryProcessingThreads() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRouteRequestFuture() - Method in class com.linkedin.venice.fastclient.transport.TransportClientResponseForRoute
- getRouteRequestMap() - Method in class com.linkedin.venice.fastclient.RequestContext
- getRouterInFlightMetricWindowSeconds() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRouterIOWorkerCount() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRouterNettyGracefulShutdownPeriodSeconds() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRouterPendingConnResumeThresholdPerRoute() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRouterPrincipalName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getRouterQuotaCheckWindow() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRouterRequest() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
- GetRouterRequest - Class in com.linkedin.venice.listener.request
-
GetRouterRequest
encapsulates a GET request to storage/resourcename/partition/key on the storage node for a single-get operation. - getRouterRootPath() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
- getRoutersClusterConfig() - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getRoutersClusterConfig() - Method in class com.linkedin.venice.helix.ZkRoutersClusterManager
- getRoutersClusterConfig(Admin) - Method in class com.linkedin.venice.controller.server.RoutersClusterConfigRoutes
-
No ACL check; any user is allowed to check router cluster configs.
- getRoutersClusterConfig(String) - Method in interface com.linkedin.venice.controller.Admin
-
Get the cluster level config for all routers.
- getRoutersClusterConfig(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getRoutersClusterConfig(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getRoutersClusterManager() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getRoutersClusterManager() - Method in class com.linkedin.venice.router.RouterServer
- getRouterUnhealthyPendingConnThresholdPerRoute() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getRoutes() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
- getRoutesForPartitionMapping() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext
- getRouteStats(MetricsRepository, String, String, RequestType) - Method in class com.linkedin.venice.fastclient.stats.ClusterRouteStats
- getRoutingDataRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getRoutingDataRepository() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getRoutingDataRepository() - Method in class com.linkedin.venice.router.RouterServer
- getRoutingInfo() - Method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
-
Gets the value of the 'routingInfo' field.
- getRoutingInfo() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'routingInfo' field.
- getRoutingPendingRequestCounterInstanceBlockThreshold() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getRoutingRequestDefaultTimeoutMS() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getRoutingStrategy() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getRoutingStrategy() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getRoutingStrategy() - Method in interface com.linkedin.venice.meta.Store
- getRoutingStrategy() - Method in class com.linkedin.venice.meta.SystemStore
- getRoutingStrategy() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'routingStrategy' field.
- getRoutingStrategy() - Method in class com.linkedin.venice.meta.ZKStore
- getRoutingStrategy() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'routingStrategy' field.
- getRoutingStrategyFromInt(int) - Static method in enum class com.linkedin.venice.meta.RoutingStrategy
- getRoutingTimedOutRequestCounterResetDelayMS() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitorConfig
- getRstErrorCount() - Method in class com.linkedin.alpini.router.impl.netty4.Router4Impl
- getRstErrorCount() - Method in interface com.linkedin.alpini.router.impl.Router
- getRunnableForKillIngestionTasksForNonCurrentVersions() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getRunningFabric() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
- getRWLockForPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Making it public is for testing purpose.
- getRWLockForPartitionOrThrow(int) - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
- getSanitizedStringForLogger(String) - Static method in class com.linkedin.venice.utils.Utils
-
Log4J's class name logging splits at the last "." and assumes it is the class name.
- getScatterGatherHelper() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandler
- getScatterGatherHelper() - Method in class com.linkedin.alpini.router.ScatterGatherRequestHandlerImpl
- getScatterGatherStatsByPath(P) - Method in class com.linkedin.alpini.router.api.ScatterGatherHelper
- getScatterGatherStatsForStore(String) - Method in class com.linkedin.venice.router.stats.AggRouterHttpRequestStats
- getScheduler() - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getSchema() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
- getSchema() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
- getSchema() - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
- getSchema() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
- getSchema() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
- getSchema() - Method in class com.linkedin.venice.client.schema.SchemaAndToString
- getSchema() - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
- getSchema() - Method in class com.linkedin.venice.client.store.schemas.TestKeyRecord
- getSchema() - Method in class com.linkedin.venice.client.store.schemas.TestValueRecord
- getSchema() - Method in class com.linkedin.venice.client.store.schemas.TestValueRecordWithMoreFields
- getSchema() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.Count
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
- getSchema() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
- getSchema() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- getSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
- getSchema() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
- getSchema() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
- getSchema() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
- getSchema() - Method in enum class com.linkedin.venice.hadoop.input.kafka.avro.MapperValueType
- getSchema() - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
- getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
- getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
- getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
- getSchema() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
- getSchema() - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
- getSchema() - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.Delete
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.GUID
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.Put
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.Update
- getSchema() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
- getSchema() - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
- getSchema() - Method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
- getSchema() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
- getSchema() - Method in class com.linkedin.venice.metadata.response.VersionProperties
- getSchema() - Method in class com.linkedin.venice.participant.protocol.KillPushJob
- getSchema() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
- getSchema() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
- getSchema() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
- getSchema() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
- getSchema() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
- getSchema() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
- getSchema() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
- getSchema() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
- getSchema() - Method in enum class com.linkedin.venice.schema.avro.ReadAvroProtocolDefinition
- getSchema() - Method in class com.linkedin.venice.schema.SchemaEntry
- getSchema() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
- getSchema() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
- getSchema() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
- getSchema() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
- getSchema() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
- getSchema() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
- getSchema() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
- getSchema() - Method in class com.linkedin.venice.storage.protocol.ChunkId
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
- getSchema() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
- getSchema(int) - Static method in class com.linkedin.venice.controller.kafka.protocol.serializer.AdminOperationSerializer
- getSchema$() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
-
Gets the value of the 'schema' field.
- getSchema$() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
-
Gets the value of the 'schema' field.
- getSchemaAdapter(Schema.Type) - Static method in interface com.linkedin.venice.schema.SchemaAdapter
-
Checks if it is possible for some value to be modified to adapt to the provided schema type.
- getSchemaAutoRegisteFromPushJobEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'schemaAutoRegisteFromPushJobEnabled' field.
- getSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
- getSchemaAutoRegisterFromPushJobEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
- getSchemaBytes() - Method in class com.linkedin.venice.schema.SchemaEntry
- getSchemaData(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getSchemaData(String) - Method in class com.linkedin.davinci.repository.RequestBasedMetaRepository
- getSchemaData(String) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
- getSchemaDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
- getSchemaDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
- getSchemaFromResource(String) - Static method in class com.linkedin.venice.utils.Utils
-
Utility function to get schemas out of embedded resources.
- getSchemaId() - Method in class com.linkedin.davinci.store.record.ValueRecord
- getSchemaId() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
-
Gets the value of the 'schemaId' field.
- getSchemaId() - Method in class com.linkedin.venice.client.store.transport.TransportClientResponse
- getSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
-
Gets the value of the 'schemaId' field.
- getSchemaId() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
-
Gets the value of the 'schemaId' field.
- getSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Delete
-
Gets the value of the 'schemaId' field.
- getSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Put
-
Gets the value of the 'schemaId' field.
- getSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Update
-
Gets the value of the 'schemaId' field.
- getSchemaId() - Method in class com.linkedin.venice.protocols.VeniceServerResponse.Builder
-
sint32 schemaId = 1;
- getSchemaId() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
-
sint32 schemaId = 1;
- getSchemaId() - Method in interface com.linkedin.venice.protocols.VeniceServerResponseOrBuilder
-
sint32 schemaId = 1;
- getSchemaId() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
-
Gets the value of the 'schemaId' field.
- getSchemaId() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
-
Gets the value of the 'schemaId' field.
- getSchemaId(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
- getSchemaId(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
- getSchemaId(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
- getSchemaID() - Method in class com.linkedin.venice.hadoop.input.kafka.chunk.ChunkAssembler.ValueBytesAndSchemaId
- getSchemaID(SchemaEntry) - Method in class com.linkedin.venice.schema.SchemaData
-
Return the schema ID of any schema that has the same parsing canonical form as the schema provided.
- getSchemaIds() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
-
Gets the value of the 'schemaIds' field.
- getSchemaIdSet() - Method in class com.linkedin.venice.controllerapi.MultiSchemaIdResponse
- getSchemaReader() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- getSchemaReader() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- getSchemaReader() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getSchemaReader() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getSchemaReader() - Method in interface com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient
- getSchemaReader() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- getSchemaReader() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- getSchemaReader() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getSchemaReader(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getSchemaReader(ClientConfig, ICProvider) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getSchemaRefreshPeriod() - Method in class com.linkedin.venice.client.store.ClientConfig
- getSchemaRepo() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getSchemaRepo() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getSchemaRepo() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
- getSchemaRepository() - Method in class com.linkedin.davinci.DaVinciBackend
- getSchemaRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getSchemaRepository() - Method in class com.linkedin.venice.router.RouterServer
- getSchemas() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse
- getSchemaStr() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse.Schema
- getSchemaStr() - Method in class com.linkedin.venice.controllerapi.SchemaResponse
- getSchemaStr() - Method in class com.linkedin.venice.schema.SchemaEntry
- getSchemaType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
-
Gets the value of the 'schemaType' field.
- getSecond() - Method in class com.linkedin.alpini.base.misc.Pair
-
Return the second value.
- getSecond() - Method in class com.linkedin.venice.utils.Pair
-
Deprecated.
- getSeconds() - Method in class com.linkedin.venice.utils.MockCircularTime
- getSeconds() - Method in class com.linkedin.venice.utils.SystemTime
- getSecureGrpcUrl() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
- getSecureGrpcUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
Secure gRPC URL for leader controller
- getSecureGrpcUrl() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
Secure gRPC URL for leader controller
- getSecureGrpcUrl() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
Secure gRPC URL for leader controller
- getSecureGrpcUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse.Builder
-
Secure gRPC URL for leader controller
- getSecureGrpcUrlBytes() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
-
Secure gRPC URL for leader controller
- getSecureGrpcUrlBytes() - Method in interface com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponseOrBuilder
-
Secure gRPC URL for leader controller
- getSecureRandomAlgorithm() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getSecureUrl() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
- getSeekThreadPoolSize() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getSeekTimestamp() - Method in class com.linkedin.venice.beam.consumer.CheckPointProperties
- getSeekTimestamp() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getSeekWhence() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getSegmentNumber() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
-
Gets the value of the 'segmentNumber' field.
- getSegmentNumber() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'segmentNumber' field.
- getSegmentNumber() - Method in class com.linkedin.venice.kafka.validation.Segment
- getSegmentNumber() - Method in class com.linkedin.venice.storage.protocol.ChunkId
-
Gets the value of the 'segmentNumber' field.
- getSegmentStatus() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
-
Gets the value of the 'segmentStatus' field.
- getSendLivenessHeartbeatFailureDetails() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'sendLivenessHeartbeatFailureDetails' field.
- getSensorFullName(String) - Method in class com.linkedin.venice.stats.AbstractVeniceStats
- getSensorFullName(String, String) - Static method in class com.linkedin.venice.stats.AbstractVeniceStats
- getSeparateRealTimeTopicEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'separateRealTimeTopicEnabled' field.
- getSeparateRealTimeTopicEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getSeparateRealTimeTopicEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'separateRealTimeTopicEnabled' field.
- getSeparateRealTimeTopicEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'separateRealTimeTopicEnabled' field.
- getSeparateRealTimeTopicName(StoreInfo) - Static method in class com.linkedin.venice.utils.Utils
- getSeparateRealTimeTopicName(Version) - Static method in class com.linkedin.venice.utils.Utils
- getSeparateRealTimeTopicName(String) - Static method in class com.linkedin.venice.utils.Utils
- getSepRTLeaderQuotaRecordsPerSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSequenceNumber() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getSequenceNumber() - Method in class com.linkedin.venice.kafka.validation.Segment
- getSerializableSystemStore() - Method in class com.linkedin.venice.meta.SystemStore
- getSerializedKey() - Method in class com.linkedin.venice.fastclient.GetRequestContext
- getSerializedKey() - Method in class com.linkedin.venice.fastclient.MultiKeyRequestContext.KeyInfo
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.LastSuccessfulAdminCommandExecutionGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.LeaderControllerGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminOperationProtocolVersionGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.UpdateAdminTopicMetadataGrpcRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
- getSerializedSize() - Method in class com.linkedin.venice.protocols.VeniceClientRequest
- getSerializedSize() - Method in class com.linkedin.venice.protocols.VeniceServerResponse
- getSerializedSize() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
- getSerializedSize() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
-
Sum of the size of the serialized, uncompressed key and value in bytes.
- getSerializedSize() - Method in class com.linkedin.venice.writer.DeleteMetadata
- getSerializedSize() - Method in class com.linkedin.venice.writer.PutMetadata
- getSerializer() - Method in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
- getSerializer(Schema) - Static method in class com.linkedin.davinci.serializer.avro.fast.MapOrderPreservingFastSerDeFactory
- getSerializer(Schema) - Static method in class com.linkedin.davinci.serializer.avro.MapOrderPreservingSerDeFactory
- getSerializer(Schema) - Method in class com.linkedin.venice.producer.AbstractVeniceProducer
- getServer() - Method in class com.linkedin.venice.grpc.VeniceGrpcServer
- getServerAdminAction() - Method in class com.linkedin.venice.listener.request.AdminRequest
- getServerClusterName() - Method in class com.linkedin.venice.fastclient.RequestContext
- getServerComputeThreadNum() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getServerConfig() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getServerConfig() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getServerConfigs() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
-
Gets the value of the 'serverConfigs' field.
- getServerD2Service() - Method in class com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponse
- getServerD2Service() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string serverD2Service = 4;
- getServerD2Service() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string serverD2Service = 4;
- getServerD2Service() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string serverD2Service = 4;
- getServerD2Service(String) - Method in interface com.linkedin.venice.controller.Admin
-
Find the server d2 service associated with a given cluster name.
- getServerD2Service(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getServerD2Service(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getServerD2ServiceBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string serverD2Service = 4;
- getServerD2ServiceBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string serverD2Service = 4;
- getServerD2ServiceBytes() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string serverD2Service = 4;
- getServerHttp2Settings() - Method in class com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer
- getServerIncrementalPushKey(int, int, String, String) - Static method in class com.linkedin.venice.common.PushStatusStoreUtils
- getServerKafkaFetchQuotaRecordsPerSecond() - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
- getServerKafkaFetchQuotaRecordsPerSecond() - Method in class com.linkedin.venice.meta.LiveClusterConfig
- getServerKafkaFetchQuotaRecordsPerSecondForRegion(String) - Method in class com.linkedin.venice.meta.LiveClusterConfig
- getServerMaxWaitForVersionInfo() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getServerPromotionToLeaderReplicaDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getServerStatsContext() - Method in class com.linkedin.venice.listener.StatsHandler
- getServerSystemStorePromotionToLeaderReplicaDelayMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getServiceDescriptor() - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc
- getServiceDescriptor() - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc
- getServiceDescriptor() - Static method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcServiceGrpc
- getServiceDescriptor() - Static method in class com.linkedin.venice.protocols.VeniceReadServiceGrpc
- getServiceDiscoveryAnnouncers() - Method in class com.linkedin.venice.controller.VeniceControllerContext
- getServiceDiscoveryAnnouncers() - Method in class com.linkedin.venice.server.VeniceServerContext
- getServiceDiscoveryRegistrationRetryMS() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getServiceDiscoveryRegistrationRetryMS() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getServiceName() - Method in class com.linkedin.venice.client.store.transport.D2TransportClient
- getServiceName() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getServices() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
- getSessionCacheSize() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getSessionId() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getSessionStartTime() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getSessionTimeout() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getShallowClassOverhead() - Method in enum class com.linkedin.venice.kafka.protocol.enums.ControlMessageType
- getSharedCache(boolean) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getSharedConsumerAssignmentStrategy() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSharedConsumerNonExistingTopicCleanupDelayMS() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getShellCmd() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand
- getShort(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getShort(CharSequence, short) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getSingleGetRouterCacheEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'singleGetRouterCacheEnabled' field.
- getSingleGetRouterCacheEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'singleGetRouterCacheEnabled' field.
- getSingleGetTardyLatencyThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getSingleKeyLongTailRetryBudgetPercentDecimal() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getSize() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
-
Gets the value of the 'size' field.
- getSize(byte[]) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
- getSize(ControlMessage) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
-
This function is imprecise in a couple of ways.
- getSize(Delete) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
- getSize(KafkaMessageEnvelope) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
-
Measure the heap usage of
KafkaMessageEnvelope
. - getSize(ProducerMetadata) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
- getSize(Put) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
- getSize(Update) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
- getSize(ByteBuffer) - Static method in class com.linkedin.venice.memory.InstanceSizeEstimator
- getSizeInBytes(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getSizeInBytes(String, long) - Method in class com.linkedin.venice.utils.VeniceProperties
- getSmallestLocalAdminOperationProtocolVersionForAllConsumers(String) - Method in class com.linkedin.venice.controller.ProtocolVersionAutoDetectionService
-
Get the smallest local admin operation protocol version for all consumers in the given cluster.
- getSmartLongTailRetryAbortThresholdMs() - Method in class com.linkedin.venice.router.api.path.VeniceMultiKeyPath
- getSmartLongTailRetryAbortThresholdMs() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getSmartLongTailRetryAbortThresholdMs() - Method in interface com.linkedin.venice.router.RouterRetryConfig
- getSmartLongTailRetryAbortThresholdMs() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getSnapshot() - Method in interface com.linkedin.alpini.router.api.HostFinder
- getSnapshotCleanupIntervalInMins() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getSnapshotCleanupIntervalInMins() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSnapshotDir() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- getSnapshotRetentionTimeInMin() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getSnapshotRetentionTimeInMin() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSocketTimeout() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getSomeTopicConfigs(Set<PubSubTopic>) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
-
Retrieves the configurations for a set of Kafka topics.
- getSomeTopicConfigs(Set<PubSubTopic>) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Retrieves the configurations for a set of PubSub topics.
- getSomeTopicConfigs(Set<PubSubTopic>) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getSomeTopicConfigs(Set<PubSubTopic>) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- getSorted() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
-
Gets the value of the 'sorted' field.
- getSorted() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'sorted' field.
- getSourceBrokerLeaderConsumerLatencySensor() - Method in class com.linkedin.davinci.stats.IngestionStats
- getSourceCluster() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getSourceCluster() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
-
Gets the value of the 'sourceCluster' field.
- getSourceConsumerRecord() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducerCallback
- getSourceFabric() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getSourceGridFabric() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getSourceKafkaCluster() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
-
Gets the value of the 'sourceKafkaCluster' field.
- getSourceKafkaServers() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
-
Gets the value of the 'sourceKafkaServers' field.
- getSourceOffsets() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
-
Gets the value of the 'sourceOffsets' field.
- getSourceOfTruthAdminAdapterFactory() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getSourceOfTruthAdminAdapterFactory() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getSourceRegion() - Method in class com.linkedin.venice.controller.repush.RepushJobRequest
- getSourceServers() - Method in class com.linkedin.davinci.kafka.consumer.TopicSwitchWrapper
- getSourceTopicName() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
-
Gets the value of the 'sourceTopicName' field.
- getSourceTopicName() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
-
Gets the value of the 'sourceTopicName' field.
- getSourceTopicPartition(PubSubTopic) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getSparkSession() - Method in class com.linkedin.venice.spark.datawriter.jobs.AbstractDataWriterSparkJob
- getSpecificAvroClient(ClientConfig<V>) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getSpecificAvroClient(String, DaVinciConfig, Class<V>) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getSpecificAvroClient(String, String, DaVinciConfig, Class<V>) - Method in class com.linkedin.davinci.client.factory.CachingDaVinciClientFactory
- getSpecificAvroClient(String, String, DaVinciConfig, Class<V>) - Method in interface com.linkedin.davinci.client.factory.DaVinciClientFactory
- getSpecificData() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
- getSpecificData() - Method in class com.linkedin.venice.admin.protocol.response.ConsumptionStateSnapshot
- getSpecificData() - Method in class com.linkedin.venice.admin.protocol.response.ServerConfigSnapshot
- getSpecificData() - Method in class com.linkedin.venice.client.change.capture.protocol.RecordChangeEvent
- getSpecificData() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
- getSpecificData() - Method in class com.linkedin.venice.compression.protocol.FakeCompressingSchema
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeOperation
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequest
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV1
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV2
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV3
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.ComputeRequestV4
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.CosineSimilarity
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.Count
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.DotProduct
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.HadamardProduct
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.request.router.ComputeRouterRequestKeyV1
- getSpecificData() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AdminOperation
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureIncrementalPushForCluster
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStoragePersona
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ETLStoreConfigRecord
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.HybridStoreConfigRecord
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.KillOfflinePushJob
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PartitionerConfigRecord
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SchemaMeta
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreViewConfigRecord
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
- getSpecificData() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
- getSpecificData() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
- getSpecificData() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperKey
- getSpecificData() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
- getSpecificData() - Method in class com.linkedin.venice.hadoop.output.avro.ValidateSchemaAndBuildDictMapperOutput
- getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionMetricsReport
- getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
- getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
- getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
- getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
- getSpecificData() - Method in class com.linkedin.venice.ingestion.protocol.ProcessShutdownCommand
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.ControlMessage
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.Delete
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.EndOfPush
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.EndOfSegment
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.KafkaMessageEnvelope
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.ProducerMetadata
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.Put
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfBufferReplay
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.ProducerPartitionState
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.TopicSwitch
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.Update
- getSpecificData() - Method in class com.linkedin.venice.kafka.protocol.VersionSwap
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentVersionStates
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.ETLStoreConfig
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.HybridStoreConfig
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.PartitionerConfig
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreAttributes
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreKeySchemas
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataKey
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
- getSpecificData() - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
- getSpecificData() - Method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
- getSpecificData() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
- getSpecificData() - Method in class com.linkedin.venice.metadata.response.VersionProperties
- getSpecificData() - Method in class com.linkedin.venice.participant.protocol.KillPushJob
- getSpecificData() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageKey
- getSpecificData() - Method in class com.linkedin.venice.participant.protocol.ParticipantMessageValue
- getSpecificData() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
- getSpecificData() - Method in class com.linkedin.venice.pushstatus.PushStatusKey
- getSpecificData() - Method in class com.linkedin.venice.pushstatus.PushStatusValue
- getSpecificData() - Method in class com.linkedin.venice.read.protocol.request.router.MultiGetRouterRequestKeyV1
- getSpecificData() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
- getSpecificData() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
- getSpecificData() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
- getSpecificData() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
- getSpecificData() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
- getSpecificData() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
- getSpecificData() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
- getSpecificData() - Method in class com.linkedin.venice.storage.protocol.ChunkedKeySuffix
- getSpecificData() - Method in class com.linkedin.venice.storage.protocol.ChunkedValueManifest
- getSpecificData() - Method in class com.linkedin.venice.storage.protocol.ChunkId
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.DataRecoveryConfig
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreETLConfig
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreHybridConfig
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreKeySchemas
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaKey
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StorePartitionerConfig
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.StoreViewConfig
- getSpecificData() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
- getSpecificData() - Method in class org.apache.avro.specific.DeterministicMapOrderSpecificDatumWriter
-
Returns the
SpecificData
implementation used by this writer. - getSpecificKeyClass() - Method in class com.linkedin.venice.client.store.ClientConfig
- getSpecificThinClient() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getSpecificValueClass() - Method in class com.linkedin.venice.client.store.ClientConfig
- getSpecificValueClass() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getSpecificValueSchema() - Method in class com.linkedin.venice.client.store.ClientConfig
- getSplits(JobConf, int) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
-
Split the topic according to the topic partition size and the allowed max record per mapper.
- getSplitsByRecordsPerSplit(JobConf, long) - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputFormat
- getSprayAllPartitionsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getSprayAllPartitionsCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getSprayAllPartitionsCount() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getSrcClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
-
Gets the value of the 'srcClusterName' field.
- getSrcClusterName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
-
Gets the value of the 'srcClusterName' field.
- getSrcClusterName() - Method in class com.linkedin.venice.controllerapi.StoreMigrationResponse
- getSrcUrl() - Method in class com.linkedin.venice.kafka.protocol.state.GlobalRtDivState
-
Gets the value of the 'srcUrl' field.
- getSsdHealthCheckShutdownTimeMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSslConfig() - Method in class com.linkedin.davinci.config.VeniceClusterConfig
- getSslConfig() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getSslConfig() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getSslConfig() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getSSLConfig() - Method in class com.linkedin.venice.security.DefaultSSLFactory
- getSSLConfig() - Method in interface com.linkedin.venice.security.SSLFactory
- getSSLConfig() - Method in class com.linkedin.venice.SSLConfig
- getSSLConfigurator(String) - Static method in interface com.linkedin.venice.hadoop.ssl.SSLConfigurator
- getSSLContext() - Method in interface com.linkedin.alpini.base.ssl.SslFactory
- getSSLContext() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
- getSSLContext() - Method in class com.linkedin.venice.security.DefaultSSLFactory
- getSSLContext() - Method in interface com.linkedin.venice.security.SSLFactory
- getSslContextProvider() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getSslEnabled() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getSslEnabled() - Method in class com.linkedin.venice.security.SSLConfig
- getSslFactory() - Method in class com.linkedin.venice.client.store.ClientConfig
- getSslFactory() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getSslFactory() - Method in class com.linkedin.venice.fastclient.GrpcClientConfig
- getSslFactory() - Method in class com.linkedin.venice.grpc.VeniceGrpcServerConfig
- getSslFactory() - Method in class com.linkedin.venice.server.VeniceServerContext
- getSSLFactory() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
- getSSLFactory() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
- getSSLFactory() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getSSLFactory(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
- getSSLFactory(Properties, String) - Static method in class com.linkedin.venice.utils.SslUtils
-
A helper function that return an instance of
SSLFactory
with ssl Properties. - getSslFactoryClassName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getSslFactoryClassName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getSSLFactoryForIngestion(VeniceConfigLoader) - Static method in class com.linkedin.davinci.ingestion.utils.IsolatedIngestionUtils
-
Create SSLFactory for D2Client in ClientConfig, which will be used by different ingestion components.
- getSslHandshakeQueueCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSslHandshakeThreadPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSslKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getSslKafkaBootstrapServers() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getSslKeyStoreLocation() - Method in class com.linkedin.venice.SSLConfig
- getSslKeyStorePassword() - Method in class com.linkedin.venice.SSLConfig
- getSSLParameters() - Method in interface com.linkedin.alpini.base.ssl.SslFactory
- getSSLParameters() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl
- getSSLParameters() - Method in class com.linkedin.venice.security.DefaultSSLFactory
- getSSLParameters() - Method in interface com.linkedin.venice.security.SSLFactory
- getSslPort() - Method in class com.linkedin.venice.meta.Instance
- getSslPort() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getSslProperties() - Method in class com.linkedin.venice.SSLConfig
- getSslProperties(VeniceProperties) - Static method in class com.linkedin.venice.hadoop.utils.VPJSSLUtils
-
Build a ssl properties based on the hadoop token file.
- getSslProtocol() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getSslStrategy(SSLFactory) - Static method in class com.linkedin.venice.httpclient.HttpClientUtils
- getSslTrustStoreLocation() - Method in class com.linkedin.venice.SSLConfig
- getSslTrustStorePassword() - Method in class com.linkedin.venice.SSLConfig
- getSstFileManager() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getSstFileManagerForMemoryLimiter() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getStackTrace(Throwable) - Static method in enum class com.linkedin.alpini.base.misc.ExceptionUtil
- getStaleRegions() - Method in class com.linkedin.venice.meta.StoreDataAudit
- getStaleStoresInCluster(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getStaleTokenCount() - Method in class com.linkedin.venice.throttle.TokenBucket
-
This method does not call #update(), so it is only accurate as of the last time #tryConsume() was called
- getStaleTopicPartitions(long) - Method in class com.linkedin.davinci.kafka.consumer.AbstractKafkaConsumerService
- getStaleTopicPartitions(long) - Method in class com.linkedin.davinci.kafka.consumer.ConsumerPollTracker
- getStaleTopicPartitions(long) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerService
- getStaleTopicPartitions(long) - Method in class com.linkedin.davinci.kafka.consumer.KafkaConsumerServiceDelegator
- getStaleUsageRatio() - Method in class com.linkedin.venice.throttle.TokenBucket
- getStartedVersion(Store) - Static method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
The intended semantic is to use this method to find the version that something is currently pushing to.
- getStartingOffset() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
-
Returns the starting offset for the split
- getStartOfBufferReplay() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'startOfBufferReplay' field.
- getStartOfBufferReplayDestinationOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'startOfBufferReplayDestinationOffset' field.
- getStartOfPushTimestamp() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getStartOfPushTimestamp() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'startOfPushTimestamp' field.
- getStartProcessingTimestamp() - Method in class com.linkedin.venice.controller.kafka.consumer.AdminOperationWrapper
- getStartTime() - Method in class com.linkedin.venice.controllerapi.AdminCommandExecution
- getStartTime() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string startTime = 4;
- getStartTime() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
string startTime = 4;
- getStartTime() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
string startTime = 4;
- getStartTimeBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder
-
string startTime = 4;
- getStartTimeBytes() - Method in class com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse
-
string startTime = 4;
- getStartTimeBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder
-
string startTime = 4;
- getStartTimeSec() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getStatCallback(ClientStats, long) - Static method in class com.linkedin.venice.client.store.StatTrackingStoreClient
- getStateMachineEngine() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getStateModelID(String, int) - Static method in class com.linkedin.davinci.helix.AbstractStateModelFactory
- getStates() - Method in class com.linkedin.venice.meta.systemstore.schemas.CurrentStoreStates
-
Gets the value of the 'states' field.
- getStateTransitionStats(String) - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
-
Use the right state transition stats for the resource.
- getStateTransitionStats(String) - Method in class com.linkedin.davinci.helix.LeaderFollowerPartitionStateModelDualPoolFactory
- getStateValue() - Method in enum class com.linkedin.venice.helix.HelixState
- getStats() - Method in interface com.linkedin.davinci.listener.response.ReadResponse
- getStats() - Method in class com.linkedin.davinci.stats.AbstractVeniceStatsReporter
- getStats() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getStats() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
- getStats() - Method in interface com.linkedin.davinci.store.StorageEngine
- getStats() - Method in class com.linkedin.davinci.StoreBackend
- getStats() - Method in class com.linkedin.venice.client.store.streaming.DelegatingTrackingCallback
- getStats() - Method in interface com.linkedin.venice.client.store.streaming.TrackingStreamingCallback
- getStats() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
- getStats() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
- getStats() - Method in class com.linkedin.venice.listener.response.ParallelMultiKeyResponseWrapper
-
N.B.: Only the individual chunks should be passed into code paths that require this API.
- getStats() - Method in class com.linkedin.venice.listener.response.SingleGetResponseWrapper
- getStats(int) - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
- getStats(RequestType) - Method in class com.linkedin.venice.fastclient.ClientConfig
- getStats(String, int) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
- getStatsByType(RequestType) - Method in class com.linkedin.venice.router.stats.RouterStats
- getStatsPrefix() - Method in class com.linkedin.venice.client.store.ClientConfig
- getStatsRecorder() - Method in class com.linkedin.venice.listener.response.AbstractReadResponse
- getStatsRecorder() - Method in class com.linkedin.venice.listener.response.MultiKeyResponseWrapper
- getStatsRecorder() - Method in class com.linkedin.venice.listener.response.ParallelMultiKeyResponseWrapper
- getStatsRecorder() - Method in class com.linkedin.venice.listener.response.SingleGetResponseWrapper
- getStatSuffix() - Method in enum class com.linkedin.davinci.kafka.consumer.ConsumerPoolType
- getStatus() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
- getStatus() - Method in class com.linkedin.venice.helix.Replica
- getStatus() - Method in interface com.linkedin.venice.jobs.ComputeJob
- getStatus() - Method in class com.linkedin.venice.jobs.DataWriterComputeJob
- getStatus() - Method in class com.linkedin.venice.kafka.validation.Segment
- getStatus() - Method in class com.linkedin.venice.listener.response.BinaryResponse
- getStatus() - Method in class com.linkedin.venice.listener.response.HttpShortcutResponse
- getStatus() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getStatus() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'status' field.
- getStatus() - Method in class com.linkedin.venice.meta.UncompletedReplica
- getStatus() - Method in interface com.linkedin.venice.meta.Version
- getStatus() - Method in class com.linkedin.venice.meta.VersionImpl
- getStatus() - Method in class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
- getStatus() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
- getStatus() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
-
Gets the value of the 'status' field.
- getStatus() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
-
Gets the value of the 'status' field.
- getStatus() - Method in class com.linkedin.venice.status.StoreStatusMessage
- getStatus() - Method in class com.linkedin.venice.systemstore.schemas.StoreReplicaStatus
-
Gets the value of the 'status' field.
- getStatus() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'status' field.
- getStatus(AsyncFuture<?>) - Static method in interface com.linkedin.alpini.base.concurrency.AsyncFuture
- getStatusCode() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
uint32 statusCode = 1;
- getStatusCode() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
uint32 statusCode = 1;
- getStatusCode() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
uint32 statusCode = 1;
- getStatusCode() - Method in interface com.linkedin.venice.router.httpclient.PortableHttpResponse
- getStatusCode() - Method in enum class com.linkedin.venice.utils.VeniceResourceCloseResult
- getStatusDetails() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
- getStatusDetails() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
-
Deprecated.Only used for JSON serialization purposes. Use
JobStatusQueryResponse.getOptionalExtraDetails()
instead. - getStatusDetails() - Method in class com.linkedin.venice.meta.UncompletedReplica
- getStatusDetails() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
-
Necessary for the JSON serde
- getStatusHistory() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getStatusHistory() - Method in class com.linkedin.venice.pushmonitor.ReplicaStatus
- getStatusStoreWriter() - Method in class com.linkedin.davinci.helix.HelixParticipationService
- getStatusUpdateTimestamp() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
- getStatusUpdateTimestamp() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
-
N.B.: Older versions of the controller did not support this timestamp, so this can be null.
- getStatusUpdateTimestamp() - Method in class com.linkedin.venice.pushmonitor.ExecutionStatusWithDetails
-
N.B.: This is not available in older controller versions, and not available for all statuses (e.g.
- getStatusUpdateTimestamp() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getStdOut() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Result
- getStepNumber() - Method in enum class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord.Step
- getStopConsumptionTimeoutInSeconds() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStopConsumptionTimeoutInSeconds() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getStoppableInstances() - Method in class com.linkedin.venice.controller.InstanceRemovableStatuses
- getStoppableInstances() - Method in class com.linkedin.venice.controllerapi.StoppableNodeStatusResponse
- getStorageClass() - Method in class com.linkedin.davinci.client.DaVinciConfig
- getStorageEngine() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngineFactory
- getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngineFactory
- getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getStorageEngine(VeniceStoreVersionConfig) - Method in class com.linkedin.davinci.store.StorageEngineFactory
-
Get an initialized storage implementation
- getStorageEngine(VeniceStoreVersionConfig, boolean) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineFactory
- getStorageEngine(VeniceStoreVersionConfig, boolean) - Method in class com.linkedin.davinci.store.StorageEngineFactory
-
Replication metadata is only supported in RocksDB storage engine.
- getStorageEngine(String) - Method in class com.linkedin.davinci.storage.StorageService
- getStorageEngine(String) - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
- getStorageEngineOverheadRatio() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getStorageEngineOverheadRatio() - Method in class com.linkedin.venice.controllerapi.StorageEngineOverheadRatioResponse
- getStorageEngineOverheadRatio(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getStorageEngineOverheadRatio(String) - Method in interface com.linkedin.venice.controller.Admin
- getStorageEngineOverheadRatio(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStorageEngineOverheadRatio(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getStorageEngineOverheadRatio(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getStorageEngineRepository() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getStorageEngineRepository() - Method in class com.linkedin.davinci.storage.StorageService
- getStorageMetadataService() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getStorageMetadataService() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
- getStorageMetadataService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getStorageMetadataService() - Method in class com.linkedin.venice.server.VeniceServer
- getStorageNodeClientType() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getStorageNodeRateLimiterType() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'storageNodeReadQuotaEnabled' field.
- getStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getStorageNodeReadQuotaEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'storageNodeReadQuotaEnabled' field.
- getStorageNodes(String) - Method in interface com.linkedin.venice.controller.Admin
- getStorageNodes(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStorageNodes(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getStorageNodesStatus(String, boolean) - Method in interface com.linkedin.venice.controller.Admin
- getStorageNodesStatus(String, boolean) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStorageNodesStatus(String, boolean) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getStorageNodesStatus(String, String) - Method in interface com.linkedin.venice.controller.Admin
-
Query and return the current status of the given storage node.
- getStorageNodesStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStorageNodesStatus(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
-
Unsupported operation in the parent controller.
- getStoragePartitionConfig(boolean, PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getStoragePartitionConfig(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getStoragePersona() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'storagePersona' field.
- getStoragePersona() - Method in class com.linkedin.venice.controllerapi.StoragePersonaResponse
- getStoragePersona() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getStoragePersona(Admin) - Method in class com.linkedin.venice.controller.server.StoragePersonaRoutes
- getStoragePersona(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getStoragePersona(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStoragePersona(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getStoragePersonaAssociatedWithStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getStoragePersonaRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getStoragePersonas() - Method in class com.linkedin.venice.controllerapi.MultiStoragePersonaResponse
- getStorageQuotaInByte() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'storageQuotaInByte' field.
- getStorageQuotaInByte() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getStorageQuotaInByte() - Method in interface com.linkedin.venice.meta.Store
- getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.StoreInfo
- getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.SystemStore
- getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'storageQuotaInByte' field.
- getStorageQuotaInByte() - Method in class com.linkedin.venice.meta.ZKStore
- getStorageQuotaInByte() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'storageQuotaInByte' field.
- getStorageService() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getStorageService() - Method in class com.linkedin.venice.server.VeniceServer
- getStore() - Method in class com.linkedin.venice.beam.consumer.CheckPointProperties
- getStore() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getStore() - Method in class com.linkedin.venice.controllerapi.StoreResponse
- getStore() - Method in class com.linkedin.venice.datarecovery.Command.Params
- getStore() - Method in class com.linkedin.venice.datarecovery.Command.Result
- getStore() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask.TaskParams
- getStore() - Method in class com.linkedin.venice.meta.StoreVersionInfo
- getStore() - Method in class com.linkedin.venice.meta.StoreVersionName
- getStore() - Method in class com.linkedin.venice.store.StoreStateReader
- getStore(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getStore(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getStore(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getStore(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
- getStore(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
-
Only the zk shared system store can be returned, otherwise this function will return null.
- getStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
- getStore(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepositoryAdapter
- getStore(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
-
Get one store by given name from repository.
- getStore(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getStore(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getStore(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStore(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getStore(String, String, String) - Static method in class com.linkedin.venice.controllerapi.ControllerClient
-
Deprecated.
- getStoreAccessController() - Method in class com.linkedin.venice.server.VeniceServerContext
- getStoreAndServerConfigs() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- getStoreAndUserPartitionsMapping() - Method in class com.linkedin.davinci.storage.StorageService
- getStoreBufferService() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getStoreCacheConfig() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheBackend
- getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
-
To avoid cycle dependency, we need to initialize another store client for schema reader.
- getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.AvroGenericStoreClientImpl
-
To avoid cycle dependency, we need to initialize another store client for schema reader.
- getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.AvroSpecificStoreClientImpl
-
To avoid cycle dependency, we need to initialize another store client for schema reader.
- getStoreClientForSchemaReader() - Method in class com.linkedin.venice.client.store.VsonGenericStoreClientImpl
-
Deprecated.
- getStoreClusterConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'storeClusterConfig' field.
- getStoreConfig(String) - Method in class com.linkedin.davinci.config.VeniceConfigLoader
- getStoreConfig(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
-
Get the store config by store name.
- getStoreConfig(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreViewConfigRepositoryAdapter
- getStoreConfig(String) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
- getStoreConfig(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreConfigRepository
- getStoreConfig(String, PersistenceType) - Method in class com.linkedin.davinci.config.VeniceConfigLoader
- getStoreConfigAccessor() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getStoreConfigOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreConfigRepository
- getStoreConfigOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreViewConfigRepositoryAdapter
- getStoreConfigOrThrow(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreConfigRepository
- getStoreConfigRepo() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
- getStoreConfigRepo() - Method in interface com.linkedin.venice.controller.Admin
-
Return a shared store config repository.
- getStoreConfigRepo() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStoreConfigRepo() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getStoreConfigs(List<String>) - Method in class com.linkedin.venice.helix.ZkStoreConfigAccessor
- getStoreDeadStatusReasons() - Method in class com.linkedin.venice.meta.StoreInfo
- getStoreDeserializerCache() - Method in class com.linkedin.davinci.StoreBackend
- getStoreFromGraveyard(String, String, Stat) - Method in class com.linkedin.venice.helix.HelixStoreGraveyard
- getStoreFromGraveyard(String, String, Stat) - Method in interface com.linkedin.venice.meta.StoreGraveyard
-
Get store from the graveyard in the specified cluster.
- getStoreFromZk(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getStoreGraveyard() - Method in interface com.linkedin.venice.controller.Admin
- getStoreGraveyard() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getStoreGraveyard() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getStoreGraveyardCleanupDelayMinutes() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getStoreGraveyardCleanupSleepIntervalBetweenListFetchMinutes() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfo() - Method in interface com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoList() - Method in class com.linkedin.venice.controllerapi.MultiStoreInfoResponse
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.DeleteAclForStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.GetAclForStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.GetAclForStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.ResourceCleanupCheckGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequest
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcRequestOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse.Builder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in class com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponse
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreInfoOrBuilder() - Method in interface com.linkedin.venice.protocols.controller.UpdateAclForStoreGrpcResponseOrBuilder
-
.com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo storeInfo = 1;
- getStoreIngestionService() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- getStoreIngestionService() - Method in class com.linkedin.davinci.ingestion.DefaultIngestionBackend
- getStoreIngestionService() - Method in interface com.linkedin.davinci.ingestion.IngestionBackend
- getStoreIngestionService() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getStoreIngestionService() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
- getStoreIngestionTask(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getStoreIngestionTask(String) - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
- getStoreIngestionTaskBuilder(String) - Static method in class com.linkedin.venice.utils.TestUtils
- getStoreKeySchemas() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'storeKeySchemas' field.
- getStoreLargestUsedVersion(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getStoreLargestUsedVersion(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getStoreLoadControllerAcceptMultiplier() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getStoreLoadControllerMaxRejectionRatio() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getStoreLoadControllerRejectionRatioUpdateIntervalInSec() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getStoreLoadControllerWindowSizeInSec() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getStoreMetadata() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getStoreMetadataFetchMode() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getStoreMetadataRepo() - Method in class com.linkedin.davinci.helix.AbstractStateModelFactory
- getStoreMetadataRepository() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getStoreMetadataSystemStoreEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'storeMetadataSystemStoreEnabled' field.
- getStoreMetaKey(Map<String, String>) - Method in enum class com.linkedin.venice.system.store.MetaStoreDataType
- getStoreMetaSystemStoreEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'storeMetaSystemStoreEnabled' field.
- getStoreMetaValue(String, StoreMetaKey) - Method in class com.linkedin.davinci.repository.ThinClientMetaStoreBasedRepository
- getStoreMetaValueAvro() - Method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
-
Gets the value of the 'storeMetaValueAvro' field.
- getStoreMetaValueSchemaVersion() - Method in class com.linkedin.venice.metadata.payload.StorePropertiesPayloadRecord
-
Gets the value of the 'storeMetaValueSchemaVersion' field.
- getStoreMigration() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getStoreMigrationAllowed() - Method in class com.linkedin.venice.controllerapi.UpdateClusterConfigQueryParams
- getStoreMigrationStartTime() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getStoreName() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- getStoreName() - Method in class com.linkedin.davinci.client.AvroGenericDaVinciClient
- getStoreName() - Method in class com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient
- getStoreName() - Method in class com.linkedin.davinci.config.StoreBackendConfig
- getStoreName() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getStoreName() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
- getStoreName() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getStoreName() - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
- getStoreName() - Method in class com.linkedin.davinci.store.StoragePartitionConfig
- getStoreName() - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
- getStoreName() - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
-
Returns the Venice store name this class is associated with.
- getStoreName() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getStoreName() - Method in interface com.linkedin.venice.client.store.AvroGenericStoreClient
- getStoreName() - Method in class com.linkedin.venice.client.store.ClientConfig
- getStoreName() - Method in class com.linkedin.venice.client.store.DelegatingStoreClient
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AbortMigration
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteAllVersions
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteStore
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteUnusedValueSchemas
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DisableStoreRead
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.EnableStoreRead
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetaSystemStoreAutoCreationValidation
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MigrateStore
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PauseStore
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.PushStatusSystemStoreAutoCreationValidation
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ResumeStore
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollbackCurrentVersion
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.RollForwardCurrentVersion
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreCurrentVersion
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStoreOwner
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SetStorePartitionCount
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ValueSchemaCreation
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.controller.multitaskscheduler.MigrationRecord
- getStoreName() - Method in class com.linkedin.venice.controller.repush.RepushJobRequest
- getStoreName() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getStoreName() - Method in exception com.linkedin.venice.exceptions.VeniceNoStoreException
- getStoreName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreAlreadyExistsException
- getStoreName() - Method in exception com.linkedin.venice.exceptions.VeniceStoreIsMigratedException
- getStoreName() - Method in class com.linkedin.venice.fastclient.ClientConfig
- getStoreName() - Method in class com.linkedin.venice.fastclient.DelegatingAvroStoreClient
- getStoreName() - Method in class com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient
- getStoreName() - Method in class com.linkedin.venice.fastclient.meta.AbstractStoreMetadata
- getStoreName() - Method in interface com.linkedin.venice.fastclient.meta.StoreMetadata
- getStoreName() - Method in exception com.linkedin.venice.hadoop.exceptions.VeniceStoreCreationException
- getStoreName() - Method in class com.linkedin.venice.listener.request.AdminRequest
- getStoreName() - Method in class com.linkedin.venice.listener.request.CurrentVersionRequest
- getStoreName() - Method in class com.linkedin.venice.listener.request.DictionaryFetchRequest
- getStoreName() - Method in class com.linkedin.venice.listener.request.MetadataFetchRequest
- getStoreName() - Method in class com.linkedin.venice.listener.request.RouterRequest
- getStoreName() - Method in class com.linkedin.venice.listener.request.StorePropertiesFetchRequest
- getStoreName() - Method in class com.linkedin.venice.listener.ServerStatsContext
- getStoreName() - Method in exception com.linkedin.venice.listener.VeniceRequestEarlyTerminationException
- getStoreName() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getStoreName() - Method in class com.linkedin.venice.meta.ReadOnlyViewStore.ReadOnlyMaterializedViewVersion
- getStoreName() - Method in class com.linkedin.venice.meta.StoreConfig
- getStoreName() - Method in class com.linkedin.venice.meta.StoreDataAudit
- getStoreName() - Method in class com.linkedin.venice.meta.StoreVersionName
- getStoreName() - Method in interface com.linkedin.venice.meta.Version
- getStoreName() - Method in class com.linkedin.venice.meta.VersionImpl
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional string storeName = 3;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
optional string storeName = 3;
- getStoreName() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
optional string storeName = 3;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
-
optional string storeName = 2;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
-
optional string storeName = 2;
- getStoreName() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequestOrBuilder
-
optional string storeName = 2;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
-
string storeName = 2;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
-
string storeName = 2;
- getStoreName() - Method in interface com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfoOrBuilder
-
string storeName = 2;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
-
string storeName = 1;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
-
string storeName = 1;
- getStoreName() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequestOrBuilder
-
string storeName = 1;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string storeName = 2;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string storeName = 2;
- getStoreName() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string storeName = 2;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional string storeName = 5;
- getStoreName() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
optional string storeName = 5;
- getStoreName() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
optional string storeName = 5;
- getStoreName() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopic
- getStoreName() - Method in class com.linkedin.venice.pubsub.PubSubTopicImpl
- getStoreName() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getStoreName() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getStoreName() - Method in exception com.linkedin.venice.router.exception.VeniceKeyCountLimitException
- getStoreName() - Method in class com.linkedin.venice.schema.SchemaData
- getStoreName() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.systemstore.schemas.StoreClusterConfig
-
Gets the value of the 'storeName' field.
- getStoreName() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'storeName' field.
- getStoreName(String) - Method in class com.linkedin.venice.meta.NameRepository
- getStoreName(String) - Static method in class com.linkedin.venice.views.VeniceView
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional string storeName = 3;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
optional string storeName = 3;
- getStoreNameBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
optional string storeName = 3;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest.Builder
-
optional string storeName = 2;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequest
-
optional string storeName = 2;
- getStoreNameBytes() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicMetadataGrpcRequestOrBuilder
-
optional string storeName = 2;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo.Builder
-
string storeName = 2;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfo
-
string storeName = 2;
- getStoreNameBytes() - Method in interface com.linkedin.venice.protocols.controller.ClusterStoreGrpcInfoOrBuilder
-
string storeName = 2;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest.Builder
-
string storeName = 1;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequest
-
string storeName = 1;
- getStoreNameBytes() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcRequestOrBuilder
-
string storeName = 1;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse.Builder
-
string storeName = 2;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponse
-
string storeName = 2;
- getStoreNameBytes() - Method in interface com.linkedin.venice.protocols.controller.DiscoverClusterGrpcResponseOrBuilder
-
string storeName = 2;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo.Builder
-
optional string storeName = 5;
- getStoreNameBytes() - Method in class com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfo
-
optional string storeName = 5;
- getStoreNameBytes() - Method in interface com.linkedin.venice.protocols.controller.VeniceControllerGrpcErrorInfoOrBuilder
-
optional string storeName = 5;
- getStoreNameFromViewStoreName(String) - Static method in class com.linkedin.venice.views.VeniceView
- getStoreOptions(StoragePartitionConfig, boolean) - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStoragePartition
- getStoreOrThrow(String) - Method in class com.linkedin.davinci.DaVinciBackend
- getStoreOrThrow(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getStoreOrThrow(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
- getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
-
Only the zk shared system store can be returned, otherwise this function will throw
VeniceNoStoreException
. - getStoreOrThrow(String) - Method in class com.linkedin.venice.helix.HelixReadWriteStoreRepository
- getStoreOrThrow(String) - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
- getStorePartitionDescription() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- getStorePath(String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getStorePersistenceType() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
- getStoreProperties() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'storeProperties' field.
- getStoreProperties(String) - Method in class com.linkedin.venice.utils.VeniceProperties
-
Get store related properties.
- getStoreProperties(String, Optional<Integer>) - Method in interface com.linkedin.davinci.storage.ReadMetadataRetriever
- getStoreProperties(String, Optional<Integer>) - Method in class com.linkedin.venice.listener.ServerReadMetadataRepository
-
Return the store properties for the given store.
- getStoreQuotaInBytes() - Method in class com.linkedin.davinci.kafka.consumer.StorageUtilizationManager
- getStoreReadThrottler(String) - Method in class com.linkedin.venice.router.throttle.ReadRequestThrottler
- getStoreRecordsInDaVinci() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
- getStoreRecordsInDaVinci() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerConfig
- getStoreReplicaStatuses() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'storeReplicaStatuses' field.
- getStoreRepo() - Method in class com.linkedin.davinci.helix.AbstractPartitionStateModel
- getStoreRepo() - Method in class com.linkedin.davinci.repository.VeniceMetadataRepositoryBuilder
- getStoreRepository() - Method in class com.linkedin.davinci.DaVinciBackend
- getStoreRepository() - Method in class com.linkedin.davinci.ingestion.isolated.IsolatedIngestionServer
- getStoreRepository() - Method in class com.linkedin.venice.listener.ReadQuotaEnforcementHandler
- getStoreRequestHandler() - Method in class com.linkedin.venice.controller.server.VeniceControllerRequestHandler
- getStores() - Method in class com.linkedin.venice.controllerapi.MultiStoreResponse
- getStoresForCompaction(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getStoresForCompaction(String) - Method in interface com.linkedin.venice.controller.Admin
-
implemented in
VeniceHelixAdmin.getStoresForCompaction(java.lang.String)
- getStoresForCompaction(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
-
- intermediary between
LogCompactionService
andCompactionManager
- injects the child controller'sControllerClient
into the functionCompactionManager.getStoresForCompaction(String, Map)
- serves as API endpoint to query stores ready for log compaction - getStoresForCompaction(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getStoresForCompaction(String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
-
This method gets a list of store names that are ready for compaction.
- getStoresForCompaction(String, Map<String, ControllerClient>) - Method in class com.linkedin.venice.controller.logcompaction.CompactionManager
-
This function iterates over a list of child controllers, in order to obtain the list of stores in each child controller, and then filter out the stores that are ready for compaction with function
CompactionManager.filterStoresForCompaction(java.util.List<com.linkedin.venice.meta.StoreInfo>)
. - getStoresFromZk() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
-
HelixReadOnlyZKSharedSystemStoreRepository
is overriding this function to filter out stores, which are not necessary to put a watch against duringCachedReadOnlyStoreRepository.refresh()
, and if this logic to refresh the zk store repository gets changed in the future, we need to updateHelixReadOnlyZKSharedSystemStoreRepository
accordingly. - getStoresFromZk() - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
-
This function is used to filter out non system stores from the system store cluster, and this is very important since
CachedReadOnlyStoreRepository.refresh()
is relying on this function to retrieve all the stores in this cluster and put a watch against each znode, and we need to filter out non-system stores to avoid unnecessary zk watches. - getStoresFromZk(Collection<String>) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getStoresInCluster(Admin) - Method in class com.linkedin.venice.controller.server.StoresRoutes
- getStoreSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngineStats
- getStoreSizeInBytes() - Method in class com.linkedin.davinci.store.StorageEngineNoOpStats
- getStoreSizeInBytes() - Method in interface com.linkedin.davinci.store.StorageEngineStats
- getStoreStats(String) - Method in class com.linkedin.venice.stats.AbstractVeniceAggStats
- getStoreStats(String) - Method in class com.linkedin.venice.stats.AbstractVeniceAggStoreStats
- getStoreStatues(List<Store>, ResourceAssignment, PushMonitor) - Static method in class com.linkedin.venice.controller.kafka.StoreStatusDecider
-
Get the statuses of given stores based on the replicas statues in the given assignment.
- getStoreStatusMap() - Method in class com.linkedin.venice.controllerapi.MultiStoreStatusResponse
- getStoresToEnforce() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.CreateStoragePersona
-
Gets the value of the 'storesToEnforce' field.
- getStoresToEnforce() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStoragePersona
-
Gets the value of the 'storesToEnforce' field.
- getStoresToEnforce() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
- getStoresToEnforce() - Method in class com.linkedin.venice.persona.Persona
- getStoresToEnforceAsList() - Method in class com.linkedin.venice.controllerapi.UpdateStoragePersonaQueryParams
- getStoreStorageQuota() - Method in class com.linkedin.venice.hadoop.InputStorageQuotaTracker
- getStoreToEarlyTerminationThresholdMSMap() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStoreType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureActiveActiveReplicationForCluster
-
Gets the value of the 'storeType' field.
- getStoreType() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.ConfigureNativeReplicationForCluster
-
Gets the value of the 'storeType' field.
- getStoreUserPartitionMapping() - Method in class com.linkedin.venice.ingestion.protocol.LoadedStoreUserPartitionMapping
-
Gets the value of the 'storeUserPartitionMapping' field.
- getStoreValueSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'storeValueSchema' field.
- getStoreValueSchemaIdsWrittenPerStoreVersion() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'storeValueSchemaIdsWrittenPerStoreVersion' field.
- getStoreValueSchemas() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'storeValueSchemas' field.
- getStoreVersion() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformer
- getStoreVersion() - Method in class com.linkedin.venice.listener.request.AdminRequest
- getStoreVersion() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatKey
-
Gets the value of the 'storeVersion' field.
- getStoreVersionCompressionDictionary(String) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getStoreVersionCompressionDictionary(String) - Method in interface com.linkedin.davinci.storage.IngestionMetadataRetriever
- getStoreVersionCompressionDictionary(String) - Method in class com.linkedin.davinci.storage.IngestionMetadataRetrieverDelegator
- getStoreVersionCompressionDictionary(String) - Method in interface com.linkedin.davinci.storage.StorageMetadataService
-
Tailored function for retrieving version's compression dictionary.
- getStoreVersionName() - Method in class com.linkedin.davinci.config.VeniceStoreVersionConfig
- getStoreVersionName() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
- getStoreVersionName() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getStoreVersionName() - Method in interface com.linkedin.davinci.store.StorageEngine
- getStoreVersionName(String) - Method in class com.linkedin.venice.meta.NameRepository
- getStoreVersionName(String, int) - Method in class com.linkedin.venice.meta.NameRepository
- getStoreVersionQpsRateLimiterType() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStoreVersionState() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPartitionMetadata
- getStoreVersionState() - Method in class com.linkedin.davinci.store.AbstractStorageEngine
-
Retrieve the store version state from the metadata partition.
- getStoreVersionState() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getStoreVersionState() - Method in interface com.linkedin.davinci.store.StorageEngine
-
Retrieve the store version state from the metadata partition.
- getStoreVersionState() - Method in class com.linkedin.venice.admin.protocol.response.AdminResponseRecord
-
Gets the value of the 'storeVersionState' field.
- getStoreVersionState() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'storeVersionState' field.
- getStoreVersionState(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionStorageMetadataService
- getStoreVersionState(String) - Method in class com.linkedin.davinci.storage.StorageEngineMetadataService
- getStoreVersionState(String) - Method in interface com.linkedin.davinci.storage.StorageMetadataService
-
Gets the currently-persisted
StoreVersionState
for this topic. - getStoreVersionState(String) - Method in class com.linkedin.venice.offsets.DeepCopyStorageMetadataService
-
Gets the currently-persisted
StoreVersionState
for this topic. - getStoreVersionState(String) - Method in class com.linkedin.venice.offsets.InMemoryStorageMetadataService
- getStoreVersionStateSyncer() - Method in class com.linkedin.davinci.storage.StorageService
- getStoreViews() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getStoreWriterBufferMemoryCapacity() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStoreWriterBufferNotifyDelta() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStoreWriterNumber() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStoreZkPath(String) - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getStrategies() - Method in class com.linkedin.venice.controllerapi.MigrationPushStrategyResponse
- getStrategy() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getStrategy() - Method in class com.linkedin.venice.pushmonitor.PushStatusDecider
- getStrategy() - Method in class com.linkedin.venice.pushmonitor.WaitAllPushStatusDecider
- getStrategy() - Method in class com.linkedin.venice.pushmonitor.WaitNMinusOnePushStatusDecider
- getStrategyClass() - Method in enum class com.linkedin.venice.router.api.routing.helix.HelixGroupSelectionStrategyEnum
- getStreamingBatchGetHeaders(int) - Static method in class com.linkedin.venice.read.RequestHeadersProvider
- getStreamingComputeHeaderMap(int, int, boolean) - Static method in class com.linkedin.venice.read.RequestHeadersProvider
- getStreamingFooterRecord(ComputeResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
- getStreamingFooterRecord(MultiGetResponseRecordV1) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
- getStreamingFooterRecord(ENVELOPE) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
- getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
- getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
- getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getStreamingRequestType() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- getString(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
- getString(String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getString(String, String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getString(String, Supplier<String>) - Method in class com.linkedin.venice.utils.VeniceProperties
- getStringKeyCharSequenceValueMapFromStringMap(Map<String, String>) - Static method in class com.linkedin.venice.utils.CollectionUtils
- getStringMap(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
- getStringMapFromCharSequenceMap(Map<CharSequence, CharSequence>) - Static method in class com.linkedin.venice.utils.CollectionUtils
- getStringSet(String) - Method in class com.linkedin.venice.controllerapi.QueryParams
- getStringToNameRecordSchema(int) - Static method in class com.linkedin.venice.utils.TestWriteUtils
- getStringWithAlternative(String, String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getStringWithAlternative(String, String, String) - Method in class com.linkedin.venice.utils.VeniceProperties
- getStuckConsumerDetectionAndRepairRunnable(Logger, Time, Map<String, AbstractKafkaConsumerService>, Map<String, StoreIngestionTask>, long, long, long, long, StuckConsumerRepairStats, Consumer<String>) - Static method in class com.linkedin.davinci.kafka.consumer.AggKafkaConsumerService
- getStuckConsumerDetectionRepairThresholdSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getStuckConsumerRepairIntervalSecond() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSubscribedViewStores(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getSubscribedViewStores(String) - Method in interface com.linkedin.davinci.repository.SubscribedViewStoreProvider
- getSubscribePrepLatencyAvg() - Method in class com.linkedin.davinci.stats.IngestionStats
- getSubscribePrepLatencyMax() - Method in class com.linkedin.davinci.stats.IngestionStats
- getSubscribeTime() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getSubscription() - Method in class com.linkedin.davinci.StoreBackend
- getSuccessfulKeyCount(Object) - Static method in class com.linkedin.venice.client.stats.BasicClientStats
-
Get the number of successful keys from the value.
- getSuccessfulPushDurationInSecs() - Method in class com.linkedin.venice.pushmonitor.OfflinePushStatus
- getSuccessMsg() - Method in class com.linkedin.davinci.stats.DIVStats
- getSuccessRequestKeyCountRate() - Method in class com.linkedin.venice.client.stats.BasicClientStats
- getSum(String, List<? extends MetricsAware>) - Static method in class com.linkedin.venice.tehuti.MetricsUtils
- getSupersetOrLatestValueSchema() - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
-
Retrieve the superset schema (if exists) or the latest value schema and return corresponding annotated value schema.
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
-
Caller shouldn't modify the returned SchemeEntry
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getSupersetOrLatestValueSchema(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getSupersetOrLatestValueSchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Get the most recent value schema or superset value schema if one exists.
- getSupersetOrLatestValueSchemaId() - Method in class com.linkedin.davinci.VersionBackend
- getSupersetSchema() - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
-
Retrieve the superset schema (if exists) and return corresponding annotated value schema.
- getSupersetSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
-
Gets the value of the 'supersetSchema' field.
- getSupersetSchema(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getSupersetSchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getSupersetSchema(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
- getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
- getSupersetSchema(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getSupersetSchema(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getSupersetSchema(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Get the superset value schema for a given store.
- getSuperSetSchemaAutoGenerationForReadComputeEnabled() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'superSetSchemaAutoGenerationForReadComputeEnabled' field.
- getSupersetSchemaFromSchemaResponse(MultiSchemaResponse, int) - Static method in class com.linkedin.venice.utils.AvroSupersetSchemaUtils
- getSupersetSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
-
Gets the value of the 'supersetSchemaId' field.
- getSuperSetSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaIdResponse
- getSuperSetSchemaId() - Method in class com.linkedin.venice.controllerapi.MultiSchemaResponse
- getSupposedlyOngoingIncrementalPushVersions(String, int) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getSystemSchemaClusterD2ServiceName() - Method in class com.linkedin.venice.controllerapi.RepushInfo
- getSystemSchemaClusterD2ZkHost() - Method in class com.linkedin.venice.controllerapi.RepushInfo
- getSystemSchemaClusterName() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getSystemSchemaClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getSystemSchemaClusterName() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getSystemSchemaClusterName() - Method in class com.linkedin.venice.router.VeniceRouterConfig
- getSystemStore() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreProperties
-
Gets the value of the 'systemStore' field.
- getSystemStoreAclFromTopicAcl(AclBinding) - Static method in enum class com.linkedin.venice.common.VeniceSystemStoreType
-
AclBinding of system store resource retrieved from authorizer service will not have the system store specific Method types and instead will either be READ or WRITE.
- getSystemStoreAclSynchronizationDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getSystemStoreAclSynchronizationDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getSystemStoreName() - Method in enum class com.linkedin.venice.serialization.avro.AvroProtocolDefinition
- getSystemStoreName(String) - Method in enum class com.linkedin.venice.common.VeniceSystemStoreType
-
This function is to compose a system store name according to the current system store type and the regular store name.
- getSystemStores() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getSystemStores() - Method in interface com.linkedin.venice.meta.Store
- getSystemStores() - Method in class com.linkedin.venice.meta.SystemStore
- getSystemStores() - Method in class com.linkedin.venice.meta.ZKStore
- getSystemStores() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'systemStores' field.
- getSystemStoreType() - Method in class com.linkedin.venice.meta.SerializableSystemStore
- getSystemStoreType() - Method in class com.linkedin.venice.meta.SystemStore
- getSystemStoreType(String) - Static method in enum class com.linkedin.venice.common.VeniceSystemStoreType
-
Retrieves the VeniceSystemStoreType for the given store name, using caching for improved performance.
- getTable(StructType, Transform[], Map<String, String>) - Method in class com.linkedin.venice.spark.input.hdfs.VeniceHdfsSource
- getTableDefinition(String, Connection) - Static method in class com.linkedin.venice.sql.SQLUtils
- getTableDefinition(String, Schema, Schema, Set<String>, AvroToSQL.UnsupportedTypeHandling, boolean) - Static method in class com.linkedin.venice.sql.AvroToSQL
- getTargetedRegions() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'targetedRegions' field.
- getTargetedRegions() - Method in class com.linkedin.venice.controllerapi.RequestTopicForPushRequest
- getTargetFileSizeInBytes() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getTargetRegion() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Params
- getTargetRegion() - Method in class com.linkedin.venice.datarecovery.MonitorCommand.Params
- getTargetRegionSwap() - Method in class com.linkedin.venice.meta.StoreInfo
- getTargetRegionSwapWaitTime() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getTargetRegionSwapWaitTime() - Method in class com.linkedin.venice.meta.StoreInfo
- getTargetSwapRegion() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'targetSwapRegion' field.
- getTargetSwapRegion() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getTargetSwapRegion() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getTargetSwapRegion() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getTargetSwapRegion() - Method in interface com.linkedin.venice.meta.Store
- getTargetSwapRegion() - Method in class com.linkedin.venice.meta.SystemStore
- getTargetSwapRegion() - Method in interface com.linkedin.venice.meta.Version
- getTargetSwapRegion() - Method in class com.linkedin.venice.meta.VersionImpl
- getTargetSwapRegion() - Method in class com.linkedin.venice.meta.ZKStore
- getTargetSwapRegion() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'targetSwapRegion' field.
- getTargetSwapRegion() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'targetSwapRegion' field.
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'targetSwapRegionWaitTime' field.
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.meta.ReadOnlyStore.ReadOnlyVersion
- getTargetSwapRegionWaitTime() - Method in interface com.linkedin.venice.meta.Store
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.meta.SystemStore
- getTargetSwapRegionWaitTime() - Method in interface com.linkedin.venice.meta.Version
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.meta.VersionImpl
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.meta.ZKStore
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'targetSwapRegionWaitTime' field.
- getTargetSwapRegionWaitTime() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'targetSwapRegionWaitTime' field.
- getTargetVersionStates() - Method in class com.linkedin.venice.meta.systemstore.schemas.TargetVersionStates
-
Gets the value of the 'targetVersionStates' field.
- getTaskId() - Method in interface com.linkedin.venice.hadoop.engine.EngineTaskConfigProvider
- getTaskId() - Method in class com.linkedin.venice.hadoop.mapreduce.engine.MapReduceEngineTaskConfigProvider
- getTaskId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractDataWriterTask
- getTaskId() - Method in class com.linkedin.venice.spark.engine.SparkEngineTaskConfigProvider
- getTaskParams() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
- getTaskResult() - Method in class com.linkedin.venice.datarecovery.DataRecoveryTask
- getTasks() - Method in class com.linkedin.venice.datarecovery.DataRecoveryWorker
- getTaskTracker() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.jobs.DataWriterMRJob
- getTaskTracker() - Method in class com.linkedin.venice.jobs.DataWriterComputeJob
- getTaskTracker() - Method in class com.linkedin.venice.spark.datawriter.jobs.AbstractDataWriterSparkJob
- getTehutiMetricConfig() - Method in class com.linkedin.venice.stats.VeniceMetricsConfig
- getTempDataDirectory() - Static method in class com.linkedin.venice.utils.TestWriteUtils
- getTempDataDirectory() - Static method in class com.linkedin.venice.utils.Utils
- getTempDataDirectory(String) - Static method in class com.linkedin.venice.utils.Utils
- getTermId() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
-
Gets the value of the 'termId' field.
- getTermId() - Method in class com.linkedin.venice.writer.LeaderMetadataWrapper
- getTerminalStateTopicCheckerDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getTerminalStateTopicCheckerDelayMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getTerminationTimeout() - Method in class com.linkedin.venice.beam.consumer.VeniceChangelogConsumerIO.Read
- getThenReset() - Method in class com.linkedin.alpini.base.concurrency.ComplexAccumulator
-
Equivalent in effect to
ComplexAccumulator.get()
followed byComplexAccumulator.reset()
. - getThenReset() - Method in class com.linkedin.alpini.base.concurrency.ConcurrentAccumulator
-
Equivalent in effect to
ConcurrentAccumulator.get()
followed byConcurrentAccumulator.reset()
. - getThenReset() - Method in class com.linkedin.alpini.base.concurrency.ThreadedAccumulator
- getThinClientGetHeaderMap() - Static method in class com.linkedin.venice.read.RequestHeadersProvider
- getThinClientStreamingBatchGetHeaders(int) - Static method in class com.linkedin.venice.read.RequestHeadersProvider
- getThread(int) - Method in class com.linkedin.venice.utils.RandomAccessDaemonThreadFactory
- getThrottlerFactorsForAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getThrottlerFactorsForCurrentVersionAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getThrottlerFactorsForCurrentVersionNonAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getThrottlerFactorsForCurrentVersionSepRTLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getThrottlerFactorsForNonCurrentVersionAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getThrottlerFactorsForNonCurrentVersionNonAAWCLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getThrottlerFactorsForSepRTLeader() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getThrottlerName() - Method in class com.linkedin.davinci.kafka.consumer.VeniceAdaptiveIngestionThrottler
- getThrottlerName() - Method in class com.linkedin.venice.throttle.EventThrottler
- getTime() - Method in class com.linkedin.venice.client.store.ClientConfig
- getTime() - Method in class com.linkedin.venice.pushmonitor.StatusSnapshot
- getTime() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getTime() - Method in class com.linkedin.venice.throttle.EventThrottler
- getTime() - Method in class com.linkedin.venice.writer.VeniceWriter
- getTime() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getTimeMillis(CharSequence) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getTimeMillis(CharSequence, long) - Method in class com.linkedin.alpini.netty4.http2.Http1Headers
- getTimeout() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
- getTimeoutProcessor() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
- getTimeSinceLastLogCompactionThresholdMS() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getTimeSinceLastLogCompactionThresholdMS() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getTimestamp() - Method in class com.linkedin.venice.datarecovery.EstimateDataRecoveryTimeCommand.Result
- getTimestamp() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getTimestamp() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreMetadataValue
-
Gets the value of the 'timestamp' field.
- getTimestamp() - Method in class com.linkedin.venice.participant.protocol.KillPushJob
-
Gets the value of the 'timestamp' field.
- getTimestamp() - Method in class com.linkedin.venice.samza.VeniceObjectWithTimestamp
- getTimestamp() - Method in class com.linkedin.venice.schema.rmd.v1.ElementTimestampAndIdx
- getTimestamp() - Method in class com.linkedin.venice.status.protocol.BatchJobHeartbeatValue
-
Gets the value of the 'timestamp' field.
- getTimestamp() - Method in class com.linkedin.venice.status.protocol.PushJobDetailsStatusTuple
-
Gets the value of the 'timestamp' field.
- getTimestamp() - Method in class com.linkedin.venice.systemstore.schemas.StoreMetaValue
-
Gets the value of the 'timestamp' field.
- getTimeStamp() - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.VeniceAvroFileIterator
- getTimeStamp() - Method in interface com.linkedin.venice.hadoop.input.recordreader.VeniceRecordIterator
-
Return the timestamp associated with the current record.
- getTimeStamp() - Method in class com.linkedin.venice.hadoop.input.recordreader.vson.VeniceVsonFileIterator
- getTimestampAfterProduce() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getTimestampBeforeProduce() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getTimestampMetadataVersionId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'timestampMetadataVersionId' field.
- getTimestampMetadataVersionId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
-
Gets the value of the 'timestampMetadataVersionId' field.
- getTimestampMetadataVersionId() - Method in interface com.linkedin.venice.meta.Version
-
Deprecated.Use
Version.getRmdVersionId()
instead - getTimestampMetadataVersionId() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'timestampMetadataVersionId' field.
- getTimestampPolicy() - Method in class com.linkedin.venice.kafka.protocol.StartOfPush
-
Gets the value of the 'timestampPolicy' field.
- getTimestampRegressionDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
- getTlsConfiguration() - Static method in class com.linkedin.venice.utils.SslUtils
- getToBeStoppedInstances() - Method in class com.linkedin.venice.controllerapi.AggregatedHealthStatusRequest
- getTombstoneCreationDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
- getTopic() - Method in class com.linkedin.davinci.consumer.VeniceChangeCoordinate
- getTopic() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getTopic() - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
- getTopic() - Method in class com.linkedin.venice.listener.request.HeartbeatRequest
- getTopic() - Method in class com.linkedin.venice.listener.request.TopicPartitionIngestionContextRequest
- getTopic() - Method in class com.linkedin.venice.meta.PartitionAssignment
- getTopic() - Method in class com.linkedin.venice.pubsub.adapter.SimplePubSubProduceResultImpl
- getTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getTopic() - Method in interface com.linkedin.venice.pubsub.api.PubSubProduceResult
-
The topic the record was appended to
- getTopic(String) - Method in class com.linkedin.venice.pubsub.PubSubTopicRepository
- getTopicAssignment() - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getTopicCleanupDelayFactor() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getTopicCleanupDelayFactor() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getTopicCleanupSleepIntervalBetweenTopicListFetchMs() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getTopicCleanupSleepIntervalBetweenTopicListFetchMs() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
-
Retrieves the configuration of a Kafka topic.
- getTopicConfig(PubSubTopic) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
-
Retrieves the configuration of a PubSub topic.
- getTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
This operation is a little heavy, since it will pull the configs for all the topics.
- getTopicConfig(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- getTopicConfigMaxRetryInMs() - Method in class com.linkedin.venice.pubsub.adapter.kafka.admin.ApacheKafkaAdminAdapter
- getTopicConfigMaxRetryInMs() - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
- getTopicConfigsResponse() - Method in class com.linkedin.venice.controllerapi.PubSubTopicConfigResponse
- getTopicConfigWithRetry(PubSubTopic) - Method in interface com.linkedin.venice.pubsub.api.PubSubAdminAdapter
- getTopicConfigWithRetry(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getTopicConfigWithRetry(PubSubTopic) - Method in class com.linkedin.venice.unit.kafka.MockInMemoryAdminAdapter
- getTopicDeletionStatusPollIntervalMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getTopicIngestionStatusMap() - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
- getTopicLatestOffsets(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Get the latest offsets for all partitions of a given topic.
- getTopicManager() - Method in interface com.linkedin.venice.controller.Admin
- getTopicManager() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getTopicManager() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getTopicManager(String) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
-
The function returns local or remote topic manager.
- getTopicManager(String) - Method in interface com.linkedin.venice.controller.Admin
- getTopicManager(String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getTopicManager(String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getTopicManager(String) - Method in class com.linkedin.venice.pubsub.manager.TopicManagerRepository
- getTopicManagerMetadataFetcherConsumerPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getTopicManagerMetadataFetcherConsumerPoolSize() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getTopicManagerMetadataFetcherThreadPoolSize() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getTopicManagerMetadataFetcherThreadPoolSize() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getTopicManagerRepository() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getTopicMaxLogCompactionLagMs(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getTopicMetadataFetcherConsumerPoolSize() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getTopicMetadataFetcherThreadPoolSize() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getTopicMinLogCompactionLagMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getTopicMinLogCompactionLagMs(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
- getTopicName() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPartitionMetadata
- getTopicName() - Method in class com.linkedin.davinci.blobtransfer.BlobTransferPayload
- getTopicName() - Method in class com.linkedin.davinci.ingestion.main.MainTopicIngestionStatus
- getTopicName() - Method in class com.linkedin.venice.ingestion.protocol.IngestionStorageMetadata
-
Gets the value of the 'topicName' field.
- getTopicName() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskCommand
-
Gets the value of the 'topicName' field.
- getTopicName() - Method in class com.linkedin.venice.ingestion.protocol.IngestionTaskReport
-
Gets the value of the 'topicName' field.
- getTopicName() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getTopicName() - Method in interface com.linkedin.venice.pubsub.api.PubSubTopicPartition
- getTopicName() - Method in class com.linkedin.venice.samza.VeniceSystemProducer
- getTopicName() - Method in class com.linkedin.venice.writer.AbstractVeniceWriter
- getTopicName() - Method in class com.linkedin.venice.writer.VeniceWriter
- getTopicName() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getTopicNameFromClusterName(String) - Static method in class com.linkedin.venice.controller.kafka.AdminTopicUtils
- getTopicNamesAndConfigsForVersion(int) - Method in class com.linkedin.davinci.store.view.ChangeCaptureViewWriter
- getTopicNamesAndConfigsForVersion(int) - Method in class com.linkedin.venice.views.ChangeCaptureView
- getTopicNamesAndConfigsForVersion(int) - Method in class com.linkedin.venice.views.MaterializedView
- getTopicNamesAndConfigsForVersion(int) - Method in class com.linkedin.venice.views.VeniceView
-
Implementations should override to return a map of topicName:topic Configs relevant for topic materialization (things like partition count, RF, etc.) TODO: Come up with list of config names that should be parsed by VeniceAdmin to pass along to TopicManager.
- getTopicOffsetCheckIntervalMs() - Method in class com.linkedin.davinci.config.VeniceServerConfig
- getTopicOffsetCheckIntervalMs() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getTopicPartition() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
- getTopicPartition() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getTopicPartition() - Method in class com.linkedin.venice.hadoop.input.kafka.KafkaInputSplit
-
Returns the topic and partition for the split
- getTopicPartition() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getTopicPartition() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getTopicPartition() - Method in class com.linkedin.venice.pubsub.PubSubTopicPartitionInfo
- getTopicPartition() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getTopicPartition(Integer) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getTopicPartitionCount(String) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
- getTopicPartitionEndOffSet(String, PubSubTopic, int) - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getTopicPartitionInfo(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Get information about all partitions for a given topic.
- getTopicPartitionIngestionContext(String, String, int) - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getTopicPartitionIngestionContext(String, String, int) - Method in interface com.linkedin.davinci.storage.IngestionMetadataRetriever
- getTopicPartitionIngestionContext(String, String, int) - Method in class com.linkedin.davinci.storage.IngestionMetadataRetrieverDelegator
- getTopicPartitionIngestionStatus(String, int) - Method in class com.linkedin.davinci.ingestion.main.MainIngestionMonitorService
- getTopicPartitionOffsetByKafkaURL(CharSequence, PubSubTopicPartition, long) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getTopicRetention(PubSubTopic) - Method in class com.linkedin.venice.pubsub.manager.TopicManager
-
Return topic retention time in MS.
- getTopicRetention(PubSubTopicConfiguration) - Static method in class com.linkedin.venice.pubsub.manager.TopicManager
- getTopics() - Method in class com.linkedin.venice.controllerapi.MultiStoreTopicsResponse
- getTopicsOfOngoingOfflinePushes() - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getTopicsOfOngoingOfflinePushes() - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
-
Find all ongoing pushes then return the topics associated to those pushes.
- getTopicsOfOngoingOfflinePushes() - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getTopicSwitch() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getTopicSwitch() - Method in class com.linkedin.davinci.kafka.consumer.TopicSwitchWrapper
- getTopicSwitch() - Method in class com.linkedin.venice.kafka.protocol.state.StoreVersionState
-
Gets the value of the 'topicSwitch' field.
- getTopicToMonitor() - Method in class com.linkedin.venice.hadoop.VenicePushJob
- getTopLevelColoID() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- getTopLevelFieldTimestamp() - Method in class com.linkedin.venice.schema.rmd.v1.CollectionRmdTimestamp
- getToString() - Method in class com.linkedin.venice.client.schema.SchemaAndToString
- getTotalCompressedValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'totalCompressedValueBytes' field.
- getTotalDCRRate() - Method in class com.linkedin.davinci.stats.IngestionStats
- getTotalEntryCount() - Method in interface com.linkedin.venice.client.store.streaming.VeniceResponseMap
-
Return the total number of entries, including non-existing keys.
- getTotalEntryCount() - Method in class com.linkedin.venice.client.store.streaming.VeniceResponseMapImpl
- getTotalEstimatedTime() - Method in class com.linkedin.venice.datarecovery.DataRecoveryEstimator
- getTotalGzipCompressedValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'totalGzipCompressedValueBytes' field.
- getTotalGzipCompressedValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getTotalGzipCompressedValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getTotalGzipCompressedValueSize() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getTotalGzipCompressedValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalIncomingDataSizeInBytes() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.reduce.VeniceReducer
- getTotalIncomingDataSizeInBytes() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter
-
Return the size of serialized key and serialized value in bytes across the entire dataset.
- getTotalIncomingDataSizeInBytes() - Method in class com.linkedin.venice.spark.datawriter.writer.SparkPartitionWriter
- getTotalInflightRequestSensor() - Method in class com.linkedin.venice.router.InFlightRequestStat
- getTotalKeyBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'totalKeyBytes' field.
- getTotalKeySize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getTotalKeySize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getTotalKeySize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getTotalKeySize() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getTotalKeySize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalKeySize(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalMemoryUsage() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
- getTotalMemoryUsage() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
- getTotalMemoryUsage() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- getTotalNumberOfOverLoadedInstances() - Method in class com.linkedin.venice.fastclient.meta.InstanceLoadController
- getTotalNumberOfRecords() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'totalNumberOfRecords' field.
- getTotalPutOrDeleteRecordsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getTotalPutOrDeleteRecordsCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getTotalPutOrDeleteRecordsCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getTotalPutOrDeleteRecordsCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalPutOrDeleteRecordsCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalRawValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'totalRawValueBytes' field.
- getTotalRemainingMemory() - Method in class com.linkedin.davinci.kafka.consumer.AbstractStoreBufferService
- getTotalRemainingMemory() - Method in class com.linkedin.davinci.kafka.consumer.SeparatedStoreBufferService
- getTotalRemainingMemory() - Method in class com.linkedin.davinci.kafka.consumer.StoreBufferService
- getTotalRetriedKeys() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
- getTotalRetriedKeys() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
- getTotalRetries() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
- getTotalRetries() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
- getTotalRetriesDiscarded() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
- getTotalRetriesDiscarded() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
- getTotalRetriesError() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
- getTotalRetriesError() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
- getTotalRetriesWinner() - Method in class com.linkedin.alpini.router.monitoring.ScatterGatherStats
- getTotalRetriesWinner() - Method in interface com.linkedin.alpini.router.monitoring.ScatterGatherStatsMBean
- getTotalStats() - Method in class com.linkedin.davinci.stats.VeniceVersionedStats
- getTotalStats() - Method in class com.linkedin.venice.stats.AbstractVeniceAggStats
- getTotalStats(String) - Method in class com.linkedin.davinci.stats.AbstractVeniceAggVersionedStats
- getTotalStoreReadQuota() - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getTotalStoreReadQuota() - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getTotalStoreReadQuota() - Method in class com.linkedin.venice.helix.CachedReadOnlyStoreRepository
- getTotalStoreReadQuota() - Method in class com.linkedin.venice.helix.HelixReadOnlyStoreRepositoryAdapter
- getTotalStoreReadQuota() - Method in class com.linkedin.venice.helix.HelixReadOnlyZKSharedSystemStoreRepository
- getTotalStoreReadQuota() - Method in interface com.linkedin.venice.meta.ReadOnlyStoreRepository
-
Get total read quota of all stores.
- getTotalUncompressedValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getTotalUncompressedValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getTotalUncompressedValueSize() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getTotalUncompressedValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getTotalValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getTotalValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getTotalValueSize() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getTotalValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalValueSize(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTotalZstdCompressedValueSize() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getTotalZstdCompressedValueSize() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getTotalZstdCompressedValueSize() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getTotalZstdWithDictCompressedValueBytes() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'totalZstdWithDictCompressedValueBytes' field.
- getTotalZstdWithDictCompressedValueSize(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getTrackedPartitions(Optional<String>) - Method in class com.linkedin.davinci.notifier.DaVinciPushStatusUpdateTask
- getTrailerHeaders() - Method in class com.linkedin.venice.read.protocol.response.streaming.StreamingFooterRecordV1
-
Gets the value of the 'trailerHeaders' field.
- getTransferMetadata(BlobTransferPayload, AtomicBoolean) - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Get the transfer metadata for a particular payload 1.
- getTransferredSnapshotMetadata(String, int) - Method in class com.linkedin.davinci.blobtransfer.BlobSnapshotManager
-
Get the snapshot metadata for a particular topic and partition
- getTransferSnapshotTableFormat() - Method in class com.linkedin.davinci.blobtransfer.P2PBlobTransferConfig
- getTransformerValueSchema() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBServerConfig
- getTransientRecord(byte[]) - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getTransientRecordMapSize() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getTransportClient() - Method in class com.linkedin.venice.client.store.AbstractAvroStoreClient
- getTransportClient(ClientConfig) - Static method in class com.linkedin.venice.client.store.ClientFactory
- getTrigger() - Method in enum class com.linkedin.davinci.stats.ingestion.heartbeat.HeartbeatLagMonitorAction
- getTriggerSource() - Method in class com.linkedin.venice.controller.repush.RepushJobRequest
- getTrustManagerAlgorithm() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getTrustManagers(SSLFactory) - Static method in class com.linkedin.venice.grpc.GrpcUtils
- getTrustStoreFilePassword() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getTrustStoreFilePassword() - Method in class com.linkedin.venice.security.SSLConfig
- getTrustStoreFilePath() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getTrustStoreFilePath() - Method in class com.linkedin.venice.security.SSLConfig
- getTrustStorePassword() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getTrustStorePath() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getTrustStoreType() - Method in class com.linkedin.venice.security.SSLConfig
- getTrustStoreType() - Method in class com.linkedin.venice.utils.SslUtils.VeniceTlsConfiguration
- getTtlInMilliseconds() - Method in class com.linkedin.davinci.store.cache.backend.ObjectCacheConfig
- getType() - Method in class com.linkedin.davinci.kafka.consumer.ConsumerAction
- getType() - Method in class com.linkedin.davinci.store.blackhole.BlackHoleStorageEngine
- getType() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStorageEngine
- getType() - Method in class com.linkedin.davinci.store.DelegatingStorageEngine
- getType() - Method in class com.linkedin.davinci.store.memory.InMemoryStorageEngine
- getType() - Method in class com.linkedin.davinci.store.rocksdb.RocksDBStorageEngine
- getType() - Method in interface com.linkedin.davinci.store.StorageEngine
- getType() - Method in class com.linkedin.venice.kafka.validation.checksum.AdHash
- getType() - Method in class com.linkedin.venice.kafka.validation.checksum.Adler32CheckSum
- getType() - Method in class com.linkedin.venice.kafka.validation.checksum.CheckSum
- getType() - Method in class com.linkedin.venice.kafka.validation.checksum.CRC32CheckSum
- getType() - Method in class com.linkedin.venice.kafka.validation.checksum.MD5CheckSum
- getType() - Method in class com.linkedin.venice.pubsub.api.PubSubPositionWireFormat
-
Gets the value of the 'type' field.
- getType() - Method in class com.linkedin.venice.schema.avro.SchemaCompatibility.SchemaPairCompatibility
-
Gets the type of this result.
- getType() - Method in class com.linkedin.venice.schema.vson.VsonSchema
-
Deprecated.
- getType() - Method in class com.linkedin.venice.sql.ColumnDefinition
- getTypeIdForFactoryClass(String) - Method in class com.linkedin.venice.pubsub.PubSubPositionTypeRegistry
-
Returns the integer type ID for the given pubsub position factory class name.
- getTypeIdForFactoryInstance(PubSubPositionFactory) - Method in class com.linkedin.venice.pubsub.PubSubPositionTypeRegistry
-
Returns the integer type ID for the given
PubSubPositionFactory
implementation. - getTypeResourceType(String) - Static method in enum class com.linkedin.venice.router.api.RouterResourceType
- getUncompletedPartitions() - Method in class com.linkedin.venice.controller.Admin.OfflinePushStatusInfo
- getUncompletedPartitions() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
- getUncompletedPartitions(String) - Method in class com.linkedin.venice.pushmonitor.AbstractPushMonitor
- getUncompletedPartitions(String) - Method in interface com.linkedin.venice.pushmonitor.PushMonitor
- getUncompletedPartitions(String) - Method in class com.linkedin.venice.pushmonitor.PushMonitorDelegator
- getUncompletedReplicas() - Method in class com.linkedin.venice.meta.UncompletedPartition
- getUncompressedRecordTooLargeFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.CounterBackedMapReduceDataWriterTaskTracker
- getUncompressedRecordTooLargeFailureCount() - Method in class com.linkedin.venice.hadoop.mapreduce.datawriter.task.ReporterBackedMapReduceDataWriterTaskTracker
- getUncompressedRecordTooLargeFailureCount() - Method in interface com.linkedin.venice.hadoop.task.datawriter.DataWriterTaskTracker
- getUncompressedRecordTooLargeFailureCount() - Method in class com.linkedin.venice.spark.datawriter.task.SparkDataWriterTaskTracker
- getUncompressedRecordTooLargeFailureCount(Counters) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getUncompressedRecordTooLargeFailureCount(Reporter) - Static method in class com.linkedin.venice.hadoop.mapreduce.counter.MRJobCounterHelper
- getUnhealthyInstanceCount() - Method in class com.linkedin.venice.fastclient.meta.InstanceHealthMonitor
- getUnhealthyRequestHttpStatus(Throwable) - Static method in class com.linkedin.venice.client.stats.BasicClientStats
-
Get the HTTP status code for unhealthy requests based on the throwable.
- getUniqueMetricEntities(Class<? extends ModuleMetricEntityInterface>...) - Static method in interface com.linkedin.venice.stats.metrics.ModuleMetricEntityInterface
-
Get all the unique
MetricEntity
from the provided enum classes based on the metric name. - getUniqueString() - Static method in class com.linkedin.venice.utils.Utils
- getUniqueString(String) - Static method in class com.linkedin.venice.utils.Utils
- getUniqueTempPath() - Static method in class com.linkedin.venice.utils.Utils
- getUniqueTempPath(String) - Static method in class com.linkedin.venice.utils.Utils
- getUniqueTopicString(String) - Static method in class com.linkedin.venice.utils.TestUtils
- getUnit() - Method in class com.linkedin.venice.stats.metrics.MetricEntity
- getUnreachableSystemStoreCounter() - Method in class com.linkedin.venice.controller.stats.SystemStoreHealthCheckStats
- getUnreadyReplicas() - Method in class com.linkedin.venice.controllerapi.NodeReplicasReadinessResponse
- getUnretrievablePartitions() - Method in class com.linkedin.venice.routerapi.ResourceStateResponse
- getUnusedSchemaCleanupIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerClusterConfig
- getUnusedSchemaCleanupIntervalSeconds() - Method in class com.linkedin.venice.controller.VeniceControllerMultiClusterConfig
- getUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'unusedSchemaDeletionEnabled' field.
- getUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getUnusedSchemaDeletionEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'unusedSchemaDeletionEnabled' field.
- getUpcomingAggregates() - Method in class com.linkedin.venice.kafka.protocol.StartOfSegment
-
Gets the value of the 'upcomingAggregates' field.
- getUpdateAclForStoreMethod() - Static method in class com.linkedin.venice.protocols.controller.StoreGrpcServiceGrpc
- getUpdateAdminOperationProtocolVersionMethod() - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc
- getUpdateAdminTopicMetadataMethod() - Static method in class com.linkedin.venice.protocols.controller.ClusterAdminOpsGrpcServiceGrpc
- getUpdateClusterConfigQueryParams(CommandLine) - Static method in class com.linkedin.venice.AdminTool
- getUpdatedConfigsList() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
-
Gets the value of the 'updatedConfigsList' field.
- getUpdatedConfigsList() - Method in class com.linkedin.venice.controllerapi.UpdateStoreQueryParams
- getUpdatedResources() - Method in class com.linkedin.venice.helix.ResourceAssignment.ResourceAssignmentChanges
- getUpdatedRmdBytes() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
- getUpdatedValue() - Method in class com.linkedin.davinci.kafka.consumer.WriteComputeResult
- getUpdatedValueBytes() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
- getUpdatedValueBytes() - Method in class com.linkedin.davinci.kafka.consumer.WriteComputeResult
- getUpdateIgnoredRate() - Method in class com.linkedin.davinci.stats.IngestionStats
- getUpdateSchema(int) - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
- getUpdateSchema(int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getUpdateSchema(int) - Method in interface com.linkedin.venice.schema.SchemaReader
- getUpdateSchema(int) - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
- getUpdateSchema(Schema) - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
- getUpdateSchema(Schema) - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
-
Returns the Update (Write Compute) schema of the provided Value schema.
- getUpdateSchemaEntry(int) - Method in class com.linkedin.venice.client.schema.RouterBasedStoreSchemaFetcher
- getUpdateSchemaEntry(int) - Method in interface com.linkedin.venice.client.schema.StoreSchemaFetcher
-
Get the latest derived schema of a value schema.
- getUpdateSchemaId() - Method in class com.linkedin.venice.kafka.protocol.Update
-
Gets the value of the 'updateSchemaId' field.
- getUpdateValue() - Method in class com.linkedin.venice.kafka.protocol.Update
-
Gets the value of the 'updateValue' field.
- getUpstreamKafkaClusterId() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
-
Gets the value of the 'upstreamKafkaClusterId' field.
- getUpstreamKafkaClusterId() - Method in class com.linkedin.venice.writer.LeaderMetadataWrapper
- getUpstreamOffset() - Method in class com.linkedin.venice.controllerapi.AdminTopicMetadataResponse
- getUpstreamOffset() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
-
Gets the value of the 'upstreamOffset' field.
- getUpstreamOffset() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata.Builder
-
optional int64 upstreamOffset = 5;
- getUpstreamOffset() - Method in class com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadata
-
optional int64 upstreamOffset = 5;
- getUpstreamOffset() - Method in interface com.linkedin.venice.protocols.controller.AdminTopicGrpcMetadataOrBuilder
-
optional int64 upstreamOffset = 5;
- getUpstreamOffset() - Method in class com.linkedin.venice.writer.LeaderMetadataWrapper
- getUpstreamOffset(String) - Method in class com.linkedin.venice.offsets.OffsetRecord
-
The caller of this API should be interested in the largest known upstream offset.
- getUpstreamOffsetMap() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'upstreamOffsetMap' field.
- getUpstreamPubSubPosition() - Method in class com.linkedin.venice.kafka.protocol.LeaderMetadata
-
Gets the value of the 'upstreamPubSubPosition' field.
- getUpstreamPubSubPosition() - Method in class com.linkedin.venice.writer.LeaderMetadataWrapper
- getUpstreamRealTimeTopicPubSubPositionMap() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'upstreamRealTimeTopicPubSubPositionMap' field.
- getUpstreamVersionTopicOffset() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'upstreamVersionTopicOffset' field.
- getUpstreamVersionTopicPubSubPosition() - Method in class com.linkedin.venice.kafka.protocol.state.PartitionState
-
Gets the value of the 'upstreamVersionTopicPubSubPosition' field.
- getUri() - Method in interface com.linkedin.alpini.base.misc.BasicRequest
-
The request URI
- getUrl() - Method in class com.linkedin.venice.controllerapi.LeaderControllerResponse
- getUrl() - Method in class com.linkedin.venice.datarecovery.StoreRepushCommand.Params
- getUrl() - Method in class com.linkedin.venice.router.httpclient.VeniceMetaDataRequest
- getUrl(boolean) - Method in class com.linkedin.venice.meta.Instance
-
Convenience method for getting a host and port based url.
- getUsage() - Method in class com.linkedin.davinci.utils.StoragePartitionDiskUsage
- getUseInsecureLegacyTlsProtocolBecauseOfBrokenPeersUsingAncientJdk() - Method in class com.linkedin.alpini.netty4.ssl.SSLEngineFactoryImpl.Config
- getUserCredentialsFromTokenFile() - Static method in class com.linkedin.venice.hadoop.ssl.UserCredentialsFactory
-
Get user's credentials from the the Hadoop token file
- getUserInputDataFrame() - Method in class com.linkedin.venice.spark.datawriter.jobs.AbstractDataWriterSparkJob
-
Get the data frame based on the user's input data.
- getUserInputDataFrame() - Method in class com.linkedin.venice.spark.datawriter.jobs.DataWriterSparkJob
- getUserPartitionLevelVenicePartitioner(PartitionerConfig) - Static method in class com.linkedin.venice.utils.PartitionUtils
-
This util method returns a new venice partitioner that works for user-level partition, regardless of the amplification factor in the partitioner config.
- getUserPartitions(String) - Method in class com.linkedin.davinci.storage.StorageService
- getUseVersionLevelHybridConfig() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'useVersionLevelHybridConfig' field.
- getUseVersionLevelIncrementalPushEnabled() - Method in class com.linkedin.venice.systemstore.schemas.StoreVersion
-
Gets the value of the 'useVersionLevelIncrementalPushEnabled' field.
- getUtf8FromGuid(GUID) - Static method in class com.linkedin.venice.guid.GuidUtils
- getValidKafkaClientProperties(VeniceProperties, PubSubSecurityProtocol, Set<String>, Set<String>) - Static method in class com.linkedin.venice.pubsub.adapter.kafka.ApacheKafkaUtils
-
Extracts and returns only the valid Kafka client configuration properties from the provided
VeniceProperties
. - getValue() - Method in class com.linkedin.alpini.base.misc.ImmutableMapEntry
- getValue() - Method in class com.linkedin.davinci.client.DaVinciRecordTransformerResult
- getValue() - Method in class com.linkedin.davinci.consumer.ImmutableChangeCapturePubSubMessage
- getValue() - Method in enum class com.linkedin.davinci.kafka.consumer.LeaderFollowerStateType
- getValue() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
- getValue() - Method in enum class com.linkedin.davinci.replication.BatchConflictResolutionPolicy
- getValue() - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
- getValue() - Method in class com.linkedin.davinci.validation.PartitionTracker.TopicType
- getValue() - Method in class com.linkedin.venice.client.change.capture.protocol.ValueBytes
-
Gets the value of the 'value' field.
- getValue() - Method in enum class com.linkedin.venice.compression.CompressionStrategy
- getValue() - Method in enum class com.linkedin.venice.compute.protocol.request.enums.ComputeOperationType
- getValue() - Method in class com.linkedin.venice.compute.protocol.response.ComputeResponseRecordV1
-
Gets the value of the 'value' field.
- getValue() - Method in enum class com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType
- getValue() - Method in enum class com.linkedin.venice.controller.kafka.protocol.enums.SchemaType
- getValue() - Method in class com.linkedin.venice.etl.VeniceKafkaDecodedRecord
-
Gets the value of the 'value' field.
- getValue() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
-
Gets the value of the 'value' field.
- getValue() - Method in enum class com.linkedin.venice.hadoop.input.kafka.ttl.TTLResolutionPolicy
- getValue() - Method in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionCommandType
- getValue() - Method in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionComponentType
- getValue() - Method in enum class com.linkedin.venice.ingestion.protocol.enums.IngestionReportType
- getValue() - Method in enum class com.linkedin.venice.kafka.protocol.enums.ControlMessageType
- getValue() - Method in enum class com.linkedin.venice.kafka.protocol.enums.MessageType
- getValue() - Method in enum class com.linkedin.venice.kafka.validation.checksum.CheckSumType
- getValue() - Method in enum class com.linkedin.venice.kafka.validation.SegmentStatus
- getValue() - Method in enum class com.linkedin.venice.meta.BackupStrategy
- getValue() - Method in enum class com.linkedin.venice.meta.BufferReplayPolicy
- getValue() - Method in enum class com.linkedin.venice.meta.DataReplicationPolicy
- getValue() - Method in enum class com.linkedin.venice.meta.IngestionMetadataUpdateType
- getValue() - Method in enum class com.linkedin.venice.meta.IngestionMode
- getValue() - Method in enum class com.linkedin.venice.meta.ServerAdminAction
- getValue() - Method in enum class com.linkedin.venice.meta.Version.PushType
- getValue() - Method in enum class com.linkedin.venice.meta.VersionStatus
- getValue() - Method in enum class com.linkedin.venice.participant.protocol.enums.ParticipantMessageType
- getValue() - Method in interface com.linkedin.venice.pubsub.api.DefaultPubSubMessage
-
Retrieves the value payload of this message.
- getValue() - Method in interface com.linkedin.venice.pubsub.api.PubSubMessage
- getValue() - Method in class com.linkedin.venice.pubsub.ImmutablePubSubMessage
- getValue() - Method in enum class com.linkedin.venice.PushJobCheckpoints
- getValue() - Method in enum class com.linkedin.venice.pushmonitor.ExecutionStatus
- getValue() - Method in enum class com.linkedin.venice.pushmonitor.PushStatusCleanUpServiceState
- getValue() - Method in class com.linkedin.venice.read.protocol.response.MultiGetResponseRecordV1
-
Gets the value of the 'value' field.
- getValue() - Method in enum class com.linkedin.venice.stats.VeniceOpenTelemetryMetricNamingFormat
- getValue() - Method in enum class com.linkedin.venice.status.PushJobDetailsStatus
- getValue() - Method in enum class com.linkedin.venice.system.store.MetaStoreDataType
- getValue() - Method in class com.linkedin.venice.utils.KeyAndValueSchemas
- getValue() - Method in class com.linkedin.venice.utils.LogContext
- getValue() - Method in class com.linkedin.venice.utils.PubSubHelper.MutableDefaultPubSubMessage
- getValue() - Method in class com.linkedin.venice.utils.ValueHolder
- getValue() - Method in interface com.linkedin.venice.utils.VeniceEnumValue
- getValue() - Method in enum class com.linkedin.venice.writer.LeaderCompleteState
- getValueBytes() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
- getValueBytes(INPUT_KEY, INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
-
Return a serialized output value
- getValueBytes(ByteBuffer, ByteBuffer) - Method in class com.linkedin.venice.hadoop.input.recordreader.avro.IdentityVeniceRecordReader
- getValueCompressionStrategy() - Method in class com.linkedin.venice.status.protocol.PushJobDetails
-
Gets the value of the 'valueCompressionStrategy' field.
- getValueDescriptor() - Method in enum class com.linkedin.venice.protocols.controller.ControllerGrpcErrorType
- getValueFromCharSequenceMapWithStringKey(Map<CharSequence, CharSequence>, String) - Static method in class com.linkedin.venice.utils.Utils
-
Given a key with type
String
and get a value (if there is one) from a map of typeMap<CharSequence,
which has one of key's toString value equals to the given String key.CharSequence> - getValueFullPathForTempSSTFileDir() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- getValueFuture() - Method in class com.linkedin.venice.client.store.transport.TransportClientCallback
- getValueLen() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
- getValueManifest() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
- getValueOffset() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
- getValueOrDerivedSchemaId(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getValueOrDerivedSchemaID(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
- getValuePayload(KafkaInputMapperValue) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceKafkaInputTTLFilter
- getValuePayload(ChunkAssembler.ValueBytesAndSchemaId) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceChunkedPayloadTTLFilter
- getValuePayload(INPUT_VALUE) - Method in class com.linkedin.venice.hadoop.input.kafka.ttl.VeniceRmdTTLFilter
- getValuePayloadSerializer() - Method in class com.linkedin.venice.writer.VeniceWriterOptions
- getValueProvider() - Method in class com.linkedin.davinci.kafka.consumer.MergeConflictResultWrapper
-
Return a best-effort value provider with the following behaviors: 1.
- getValueProvider() - Method in class com.linkedin.davinci.kafka.consumer.WriteComputeResultWrapper
-
Return a best-effort value provider with the following behaviors: 1.
- getValueRecord() - Method in class com.linkedin.venice.listener.response.SingleGetResponseWrapper
- getValueRecord(ComputeResponseRecordV1, CompressionStrategy) - Method in class com.linkedin.venice.client.store.streaming.ComputeRecordStreamDecoder
- getValueRecord(MultiGetResponseRecordV1, CompressionStrategy) - Method in class com.linkedin.venice.client.store.streaming.MultiGetRecordStreamDecoder
- getValueRecord(ENVELOPE, CompressionStrategy) - Method in class com.linkedin.venice.client.store.streaming.AbstractRecordStreamDecoder
- getValueRocksDBSstFileWriter() - Method in class com.linkedin.davinci.store.rocksdb.ReplicationMetadataRocksDBStoragePartition
- getValueSchema() - Method in class com.linkedin.venice.client.store.ComputeGenericRecord
- getValueSchema() - Method in enum class com.linkedin.venice.common.VeniceSystemStoreType
- getValueSchema() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
- getValueSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.StoreCreation
-
Gets the value of the 'valueSchema' field.
- getValueSchema() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
-
Gets the value of the 'valueSchema' field.
- getValueSchema() - Method in class com.linkedin.venice.hadoop.input.recordreader.AbstractVeniceRecordReader
- getValueSchema() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
string valueSchema = 3;
- getValueSchema() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
string valueSchema = 3;
- getValueSchema() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
string valueSchema = 3;
- getValueSchema() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchema
-
Gets the value of the 'valueSchema' field.
- getValueSchema(int) - Method in class com.linkedin.davinci.replication.merge.StringAnnotatedStoreSchemaCache
-
Retrieve value schema and annotate its top-level string array and map fields.
- getValueSchema(int) - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
- getValueSchema(int) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getValueSchema(int) - Method in class com.linkedin.venice.schema.SchemaData
- getValueSchema(int) - Method in interface com.linkedin.venice.schema.SchemaReader
- getValueSchema(int) - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
- getValueSchema(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
-
Route to handle retrieving value schema by id.
- getValueSchema(String, int) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getValueSchema(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
-
This function is used to retrieve the value schema for the given store and value schema id.
- getValueSchema(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getValueSchema(String, int) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
-
This function is used to retrieve the value schema for the given store and value schema id.
- getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
-
Get value schema for the given store and schema id.
- getValueSchema(String, int) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getValueSchema(String, int) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getValueSchema(String, int) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Get value schema for the given store and value schema id.
- getValueSchema(String, String) - Method in class com.linkedin.venice.helix.HelixSchemaAccessor
- getValueSchema(String, String, int) - Method in interface com.linkedin.venice.controller.Admin
- getValueSchema(String, String, int) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getValueSchema(String, String, int) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getValueSchemaBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest.Builder
-
string valueSchema = 3;
- getValueSchemaBytes() - Method in class com.linkedin.venice.protocols.controller.CreateStoreGrpcRequest
-
string valueSchema = 3;
- getValueSchemaBytes() - Method in interface com.linkedin.venice.protocols.controller.CreateStoreGrpcRequestOrBuilder
-
string valueSchema = 3;
- getValueSchemaFromETLValueSchema(Schema, ETLValueSchemaTransformation) - Static method in class com.linkedin.venice.etl.ETLUtils
-
Get the store's value schema from it's value schema in the ETL output and the transformation that was applied to construct it.
- getValueSchemaId() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState.TransientRecord
- getValueSchemaId() - Method in class com.linkedin.davinci.replication.merge.MergeConflictResult
- getValueSchemaId() - Method in class com.linkedin.davinci.replication.RmdWithValueSchemaId
- getValueSchemaId() - Method in class com.linkedin.davinci.schema.merge.ValueAndRmd
- getValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DerivedSchemaCreation
-
Gets the value of the 'valueSchemaId' field.
- getValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.MetadataSchemaCreation
-
Gets the value of the 'valueSchemaId' field.
- getValueSchemaId() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.SupersetSchemaCreation
-
Gets the value of the 'valueSchemaId' field.
- getValueSchemaId() - Method in class com.linkedin.venice.hadoop.task.datawriter.AbstractPartitionWriter.VeniceWriterMessage
- getValueSchemaId() - Method in class com.linkedin.venice.listener.request.ComputeRouterRequestWrapper
- getValueSchemaId() - Method in class com.linkedin.venice.writer.DeleteMetadata
- getValueSchemaId(String, String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getValueSchemaId(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
-
This function is used to retrieve value schema id for the given store and schema.
- getValueSchemaId(String, String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
-
This function is used to retrieve value schema id for the given store and schema.
- getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
-
This function is used to retrieve value schema id for the given store and schema.
- getValueSchemaId(String, String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getValueSchemaId(String, String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getValueSchemaId(String, String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Return the schema ID of any schema for the store that has the same parsing canonical form as the schema provided.
- getValueSchemaId(String, String, String) - Method in interface com.linkedin.venice.controller.Admin
- getValueSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getValueSchemaId(String, String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getValueSchemaId(Schema) - Method in class com.linkedin.venice.client.schema.RouterBackedSchemaReader
- getValueSchemaId(Schema) - Method in class com.linkedin.venice.fastclient.meta.RequestBasedMetadata
- getValueSchemaId(Schema) - Method in interface com.linkedin.venice.schema.SchemaReader
-
Return the schema ID of any schema that has the same parsing canonical form as the schema provided.
- getValueSchemaId(Schema) - Method in class com.linkedin.venice.schema.SchemaRepoBackedSchemaReader
- getValueSchemaID() - Method in class com.linkedin.venice.compute.ComputeRequestWrapper
- getValueSchemaID() - Method in class com.linkedin.venice.schema.GeneratedSchemaEntry
- getValueSchemaID() - Method in class com.linkedin.venice.schema.GeneratedSchemaID
- getValueSchemaID() - Method in class com.linkedin.venice.schema.rmd.RmdVersionId
- getValueSchemaID(Admin) - Method in class com.linkedin.venice.controller.server.SchemaRoutes
-
Route to handle retrieving schema id by schema.
- getValueSchemaID(String, String) - Method in class com.linkedin.venice.controllerapi.ControllerClient
- getValueSchemaInternally(String, int) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getValueSchemaMap() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreValueSchemas
-
Gets the value of the 'valueSchemaMap' field.
- getValueSchemaMap() - Method in class com.linkedin.venice.systemstore.schemas.StoreValueSchemas
-
Gets the value of the 'valueSchemaMap' field.
- getValueSchemaPath() - Method in class com.linkedin.venice.hadoop.schema.HDFSSchemaSource
- getValueSchemas() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'valueSchemas' field.
- getValueSchemas() - Method in class com.linkedin.venice.schema.SchemaData
- getValueSchemas(String) - Method in class com.linkedin.davinci.consumer.RecordChangeEventReadOnlySchemaRepository
- getValueSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
-
This function is used to retrieve all the value schemas for the given store.
- getValueSchemas(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepository
-
This function is used to retrieve all the value schemas for the given store.
- getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadOnlySchemaRepositoryAdapter
- getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepository
-
This function is used to retrieve all the value schemas for the given store.
- getValueSchemas(String) - Method in class com.linkedin.venice.helix.HelixReadWriteSchemaRepositoryAdapter
- getValueSchemas(String) - Method in class com.linkedin.venice.listener.StoreValueSchemasCacheService
- getValueSchemas(String) - Method in interface com.linkedin.venice.meta.ReadOnlySchemaRepository
-
Get all the value schemas for the given store.
- getValueSchemas(String, String) - Method in interface com.linkedin.venice.controller.Admin
- getValueSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getValueSchemas(String, String) - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getValueSerializer() - Method in class com.linkedin.venice.pubsub.api.PubSubMessageDeserializer
- getValueToCount(String) - Method in interface com.linkedin.venice.client.store.ComputeAggregationResponse
- getValueType() - Method in class com.linkedin.venice.hadoop.input.kafka.avro.KafkaInputMapperValue
-
Gets the value of the 'valueType' field.
- getValueUnion() - Method in class com.linkedin.davinci.kafka.consumer.LeaderProducedRecordContext
- getVeniceAdminStats() - Method in class com.linkedin.venice.controller.HelixVeniceClusterResources
- getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VeniceComputePath
- getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VeniceMultiGetPath
- getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getVeniceApiVersionHeader() - Method in class com.linkedin.venice.router.api.path.VeniceSingleGetPath
- getVeniceCache() - Method in class com.linkedin.davinci.store.cache.VeniceStoreCacheStoragePartition
- getVeniceChangeCoordinates() - Method in class com.linkedin.venice.beam.consumer.VeniceCheckpointMark
- getVeniceChangelogConsumer(String) - Method in class com.linkedin.venice.beam.consumer.LocalVeniceChangelogConsumerProvider
- getVeniceChangelogConsumer(String) - Method in interface com.linkedin.venice.beam.consumer.VeniceChangelogConsumerProvider
- getVeniceChangelogConsumer(String, String) - Method in class com.linkedin.venice.beam.consumer.LocalVeniceChangelogConsumerProvider
- getVeniceChangelogConsumer(String, String) - Method in interface com.linkedin.venice.beam.consumer.VeniceChangelogConsumerProvider
- getVeniceClientRequest() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
- getVeniceCluster(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepository
- getVeniceCluster(String) - Method in class com.linkedin.davinci.repository.NativeMetadataRepositoryViewAdapter
- getVeniceCluster(String) - Method in interface com.linkedin.venice.meta.ClusterInfoProvider
-
Get the associated Venice cluster name given a Venice store name.
- getVeniceCluster(String) - Method in class com.linkedin.venice.meta.StaticClusterInfoProvider
- getVeniceClusterConfig() - Method in class com.linkedin.davinci.config.VeniceConfigLoader
- getVeniceClusterNameFromPartitionName(String) - Static method in class com.linkedin.venice.controller.VeniceControllerStateModel
-
Get the regular Venice cluster name after removing the suffix
PARTITION_SUFFIX
. - getVeniceComponent() - Method in class com.linkedin.venice.pubsub.manager.TopicManagerContext
- getVeniceConfigLoader() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getVeniceConfigLoader() - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
- getVeniceConfigLoader() - Method in class com.linkedin.venice.server.VeniceServerContext
- getVeniceControllerService() - Method in class com.linkedin.venice.controller.VeniceController
- getVeniceDiscoveryUrl() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getVeniceHelixAdmin() - Method in class com.linkedin.venice.controller.VeniceControllerService
- getVeniceHelixAdmin() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getVeniceHttpResponseStatusCodeCategory(int) - Static method in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusCodeCategory
- getVeniceHttpResponseStatusCodeCategory(HttpResponseStatus) - Static method in enum class com.linkedin.venice.stats.dimensions.HttpResponseStatusCodeCategory
- getVeniceLocalSslFactory() - Static method in class com.linkedin.venice.utils.SslUtils
-
This function should be used in test cases only.
- getVeniceLocalSslProperties() - Static method in class com.linkedin.venice.utils.SslUtils
-
This function should be used in test cases only.
- getVeniceMetricsConfig() - Method in class com.linkedin.venice.stats.VeniceMetricsRepository
- getVeniceMetricsRepository(ClientType, Collection<MetricEntity>, boolean) - Static method in class com.linkedin.venice.stats.VeniceMetricsRepository
- getVeniceMetricsRepository(ClientType, Collection<MetricEntity>, boolean, MetricReader) - Static method in class com.linkedin.venice.stats.VeniceMetricsRepository
- getVeniceMetricsRepository(String, String, Collection<MetricEntity>, Map<String, String>) - Static method in class com.linkedin.venice.stats.VeniceMetricsRepository
- getVeniceOfflinePushMonitorAccessor() - Method in class com.linkedin.davinci.helix.HelixParticipationService
- getVenicePartitioner(PartitionerConfig) - Static method in class com.linkedin.venice.utils.PartitionUtils
- getVenicePartitioner(VeniceProperties) - Static method in class com.linkedin.venice.utils.PartitionUtils
- getVenicePartitioner(String, VeniceProperties) - Static method in class com.linkedin.venice.utils.PartitionUtils
- getVenicePartitioner(String, VeniceProperties, Schema) - Static method in class com.linkedin.venice.utils.PartitionUtils
- getVenicePartitioner(String, String) - Static method in class com.linkedin.venice.utils.PartitionUtils
- getVenicePathParser(CompressorFactory, boolean) - Static method in class com.linkedin.venice.utils.TestUtils
- getVeniceProperties() - Method in class com.linkedin.venice.controller.ControllerRequestHandlerDependencies
- getVeniceProperties() - Method in class com.linkedin.venice.pubsub.PubSubAdminAdapterContext
- getVeniceProperties() - Method in class com.linkedin.venice.pubsub.PubSubConsumerAdapterContext
- getVeniceProperties() - Method in class com.linkedin.venice.pubsub.PubSubProducerAdapterContext
- getVeniceProps(JobConf) - Static method in class com.linkedin.venice.hadoop.utils.HadoopUtils
- getVenicePushStatus() - Method in class com.linkedin.venice.routerapi.ReplicaState
- getVeniceRouterUrl() - Method in class com.linkedin.venice.pulsar.sink.VenicePulsarSinkConfig
- getVeniceServerConfig() - Method in class com.linkedin.davinci.config.VeniceConfigLoader
- getVeniceServerResponseBuilder() - Method in class com.linkedin.venice.listener.grpc.GrpcRequestContext
- getVeniceStore() - Method in class com.linkedin.venice.meta.SerializableSystemStore
- getVeniceStore() - Method in class com.linkedin.venice.meta.SystemStore
- getVeniceURL() - Method in class com.linkedin.venice.client.store.ClientConfig
- getVeniceVersionFromClassPath() - Static method in class com.linkedin.venice.utils.Utils
-
This might not work when application is running inside application server like Jetty
- getVeniceView(String, Properties, String, Map<String, String>) - Static method in class com.linkedin.venice.views.ViewUtils
- getVeniceViewWriter(String, VeniceConfigLoader, Store, int, Schema, Map<String, String>, VeniceWriterFactory) - Static method in class com.linkedin.davinci.store.view.ViewWriterUtils
- getVeniceViewWriterFactory() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getVeniceWriter(PartitionConsumptionState) - Method in class com.linkedin.davinci.kafka.consumer.LeaderFollowerStoreIngestionTask
- getVeniceWriter(VersionCreationResponse) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
-
This method is overridden and not used by LinkedIn internally.
- getVeniceWriter(VersionCreationResponse, Properties) - Method in class com.linkedin.venice.samza.VeniceSystemProducer
-
Please don't remove this method since it is still being used by LinkedIn internally.
- getVeniceWriter(String, PartitionerConfig, Properties, int) - Method in class com.linkedin.venice.heartbeat.DefaultPushJobHeartbeatSenderFactory
- getVeniceWriterFactory() - Method in class com.linkedin.davinci.kafka.consumer.KafkaStoreIngestionService
- getVeniceWriterFactory() - Method in interface com.linkedin.davinci.kafka.consumer.StoreIngestionService
- getVeniceWriterFactory() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getVeniceWriterFactory() - Method in interface com.linkedin.venice.controller.Admin
- getVeniceWriterFactory() - Method in class com.linkedin.venice.controller.VeniceHelixAdmin
- getVeniceWriterFactory() - Method in class com.linkedin.venice.controller.VeniceParentHelixAdmin
- getVeniceWriterFactory(Properties, PubSubProducerAdapterFactory, PubSubPositionTypeRegistry) - Static method in class com.linkedin.venice.utils.TestUtils
- getVeniceWriterLazyRef() - Method in class com.linkedin.davinci.kafka.consumer.PartitionConsumptionState
- getVersion() - Method in class com.linkedin.davinci.VersionBackend
- getVersion() - Method in class com.linkedin.venice.controllerapi.JobStatusQueryResponse
- getVersion() - Method in class com.linkedin.venice.controllerapi.MultiReplicaResponse
- getVersion() - Method in class com.linkedin.venice.controllerapi.RepushInfo
- getVersion() - Method in class com.linkedin.venice.controllerapi.routes.PushJobStatusUploadResponse
- getVersion() - Method in class com.linkedin.venice.controllerapi.VersionResponse
- getVersion() - Method in exception com.linkedin.venice.exceptions.VeniceNoHelixResourceException
- getVersion() - Method in class com.linkedin.venice.helix.SafeHelixManager
- getVersion() - Method in class com.linkedin.venice.kafka.protocol.EndOfIncrementalPush
-
Gets the value of the 'version' field.
- getVersion() - Method in class com.linkedin.venice.kafka.protocol.StartOfIncrementalPush
-
Gets the value of the 'version' field.
- getVersion() - Method in class com.linkedin.venice.kafka.protocol.state.IncrementalPush
-
Gets the value of the 'version' field.
- getVersion() - Method in class com.linkedin.venice.meta.StoreVersionInfo
- getVersion(int) - Method in class com.linkedin.venice.meta.AbstractStore
- getVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getVersion(int) - Method in class com.linkedin.venice.meta.ReadOnlyViewStore
- getVersion(int) - Method in interface com.linkedin.venice.meta.Store
- getVersion(int) - Method in class com.linkedin.venice.meta.StoreInfo
- getVersion(String, BasicFullHttpRequest) - Method in class com.linkedin.venice.router.api.VeniceVersionFinder
- getVersionCompressor(PubSubTopicPartition) - Method in class com.linkedin.davinci.consumer.VeniceChangelogConsumerImpl
- getVersionedDIVStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getVersionedDIVStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getVersionedStorageIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTaskFactory.Builder
- getVersionIngestionStats() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getVersionMetadata() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'versionMetadata' field.
- getVersionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'versionNum' field.
- getVersionNum() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.DeleteOldVersion
-
Gets the value of the 'versionNum' field.
- getVersionNumber() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getVersionNumber() - Method in class com.linkedin.venice.meta.StoreVersionName
- getVersionNumber() - Method in class com.linkedin.venice.meta.systemstore.schemas.StoreVersionState
-
Gets the value of the 'versionNumber' field.
- getVersionNumber() - Method in class com.linkedin.venice.router.api.path.VenicePath
- getVersionNumber() - Method in class com.linkedin.venice.status.protocol.PushJobStatusRecordKey
-
Gets the value of the 'versionNumber' field.
- getVersionNumbers() - Method in interface com.linkedin.venice.meta.Store
- getVersionOrThrow(int) - Method in class com.linkedin.venice.meta.AbstractStore
- getVersionOrThrow(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getVersionOrThrow(int) - Method in class com.linkedin.venice.meta.ReadOnlyViewStore
- getVersionOrThrow(int) - Method in interface com.linkedin.venice.meta.Store
- getVersionRole() - Method in class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext
- getVersions() - Method in class com.linkedin.venice.controllerapi.MultiVersionResponse
- getVersions() - Method in class com.linkedin.venice.meta.AbstractStore
- getVersions() - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getVersions() - Method in class com.linkedin.venice.meta.ReadOnlyViewStore
- getVersions() - Method in class com.linkedin.venice.meta.RegionPushDetails
- getVersions() - Method in interface com.linkedin.venice.meta.Store
- getVersions() - Method in class com.linkedin.venice.meta.StoreInfo
-
List of available versions for this store
- getVersions() - Method in interface com.linkedin.venice.meta.SystemStoreAttributes
- getVersions() - Method in class com.linkedin.venice.meta.SystemStoreAttributesImpl
- getVersions() - Method in class com.linkedin.venice.metadata.response.MetadataResponseRecord
-
Gets the value of the 'versions' field.
- getVersions() - Method in class com.linkedin.venice.systemstore.schemas.StoreProperties
-
Gets the value of the 'versions' field.
- getVersions() - Method in class com.linkedin.venice.systemstore.schemas.SystemStoreProperties
-
Gets the value of the 'versions' field.
- getVersionSpecificCompressor(String) - Method in class com.linkedin.venice.compression.CompressorFactory
- getVersionStateDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonInfo
- getVersionStateDiff() - Method in class com.linkedin.venice.controllerapi.StoreComparisonResponse
- getVersionStatus(int) - Method in class com.linkedin.venice.meta.AbstractStore
- getVersionStatus(int) - Method in class com.linkedin.venice.meta.ReadOnlyStore
- getVersionStatus(int) - Method in interface com.linkedin.venice.meta.Store
- getVersionStatus(String, int, Optional<String>) - Method in class com.linkedin.venice.pushstatushelper.PushStatusStoreReader
- getVersionStatusFromInt(int) - Static method in enum class com.linkedin.venice.meta.VersionStatus
- getVersionStatusMap() - Method in class com.linkedin.venice.controllerapi.MultiVersionStatusResponse
- getVersionSwapDeferred() - Method in class com.linkedin.venice.controller.kafka.protocol.admin.AddVersion
-
Gets the value of the 'versionSwapDeferred' field.
- getVersionSwapDetectionIntervalTimeInSeconds() - Method in class com.linkedin.davinci.consumer.ChangelogClientConfig
- getVersionTopic() - Method in class com.linkedin.davinci.kafka.consumer.PartitionReplicaIngestionContext
- getVersionTopic() - Method in class com.linkedin.davinci.kafka.consumer.StoreIngestionTask
- getVersionTopic() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionForIngestion
- getVersionTopic() - Method in class com.linkedin.venice.listener.request.TopicPartitionIngestionContextRequest
- getVersionTopicEndOffsetRewindCount() - Method in class com.linkedin.davinci.stats.IngestionStats
- getVersionTopicName() - Method in class com.linkedin.davinci.kafka.consumer.TopicPartitionIngestionInfo