Skip navigation links
  • Overview
  • Package
  • Class
  • Tree
  • Deprecated
  • Index
  • Help

Deprecated API

Contents

  • Classes
  • Enum Classes
  • Fields
  • Methods
  • Constructors
  • Enum Constants
  • Deprecated Classes
    Class
    Description
    com.linkedin.venice.client.store.VsonGenericStoreClientImpl
    com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponseV2
    com.linkedin.venice.fastclient.DispatchingVsonStoreClient
    com.linkedin.venice.schema.vson.AbstractVsonSchemaAdapter
    com.linkedin.venice.schema.vson.VsonAvroDatumReader
    com.linkedin.venice.schema.vson.VsonAvroDatumWriter
    com.linkedin.venice.schema.vson.VsonAvroSchemaAdapter
    com.linkedin.venice.schema.vson.VsonAvroSerializer
    com.linkedin.venice.schema.vson.VsonReader
    com.linkedin.venice.schema.vson.VsonSchema
    com.linkedin.venice.schema.vson.VsonSchemaAdapter
    com.linkedin.venice.stats.LambdaStat
    , use Gauge instead. The reason to deprecate LambdaStat is that Gauge is a better name when appending the class name as the suffix of metric name here: AbstractVeniceStats.registerSensor(String, Sensor[], MeasurableStat...).
    com.linkedin.venice.utils.Pair
    Instead of this, please create a dedicated class with well-named, non-generic (potentially primitive) properties and getters.
  • Deprecated Enum Classes
    Enum Class
    Description
    com.linkedin.venice.exceptions.ExceptionType
    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.
    com.linkedin.venice.schema.vson.VsonTypes
    com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl
  • Deprecated Fields
    Field
    Description
    com.linkedin.venice.ConfigKeys.CHILD_CLUSTER_WHITELIST
    com.linkedin.venice.ConfigKeys.ENABLE_HYBRID_PUSH_SSL_WHITELIST
    com.linkedin.venice.ConfigKeys.ENABLE_OFFLINE_PUSH_SSL_WHITELIST
    com.linkedin.venice.ConfigKeys.NATIVE_REPLICATION_FABRIC_WHITELIST
    com.linkedin.venice.ConfigKeys.PUB_SUB_ADMIN_ADAPTER_FACTORY_CLASS
    Use ConfigKeys.PUBSUB_ADMIN_ADAPTER_FACTORY_CLASS instead. This legacy config key uses the older "pub.sub" naming convention.
    com.linkedin.venice.ConfigKeys.PUB_SUB_CONSUMER_ADAPTER_FACTORY_CLASS
    Use ConfigKeys.PUBSUB_CONSUMER_ADAPTER_FACTORY_CLASS instead. This legacy config key uses the older "pub.sub" naming convention.
    com.linkedin.venice.ConfigKeys.PUB_SUB_PRODUCER_ADAPTER_FACTORY_CLASS
    Use ConfigKeys.PUBSUB_PRODUCER_ADAPTER_FACTORY_CLASS instead. This legacy config key uses the older "pub.sub" naming convention.
    com.linkedin.venice.ConfigKeys.PUB_SUB_SOURCE_OF_TRUTH_ADMIN_ADAPTER_FACTORY_CLASS
    Use ConfigKeys.PUBSUB_SOURCE_OF_TRUTH_ADMIN_ADAPTER_FACTORY_CLASS instead. This legacy config key uses the older "pub.sub" naming convention.
    com.linkedin.venice.ConfigKeys.PUSH_SSL_WHITELIST
    com.linkedin.venice.ConfigKeys.SSL_TO_KAFKA_LEGACY
    Use ConfigKeys.KAFKA_OVER_SSL
    com.linkedin.venice.controllerapi.ControllerApiConstants.NAME
    Use ControllerApiConstants.STORE_NAME instead.
    com.linkedin.venice.controllerapi.ControllerApiConstants.STORE_MIGRATION
    Use ControllerApiConstants.ENABLE_STORE_MIGRATION instead. This constant is kept for backward compatibility and will be removed in a future release.
    com.linkedin.venice.controllerapi.D2ServiceDiscoveryResponseV2.D2_SERVICE_DISCOVERY_RESPONSE_V2_ENABLED
    com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerConfig.SSL_TO_KAFKA_LEGACY
    Use ApacheKafkaProducerConfig.KAFKA_OVER_SSL instead
    com.linkedin.venice.router.api.VenicePathParser.TYPE_LEADER_CONTROLLER_LEGACY
    com.linkedin.venice.serialization.avro.InternalAvroSpecificSerializer.VENICE_SCHEMA_READER_CONFIG
    com.linkedin.venice.vpj.VenicePushJobConstants.VSON_PUSH
  • Deprecated Methods
    Method
    Description
    com.linkedin.alpini.io.ssl.SSLContextBuilder.build(String, String)
    Builds from key store file instead of raw key store data.
    com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer.isUseCustomMultiplexHandler()
    com.linkedin.alpini.netty4.handlers.BasicServerChannelInitializer.useCustomMultiplexHandler(boolean)
    com.linkedin.alpini.netty4.misc.Http2Utils.isHttp2Pipeline(ChannelPipeline)
    com.linkedin.alpini.router.api.ScatterGatherMode.scatter(Scatter<H, P, K>, String, String, PartitionFinder<K>, HostFinder<H, R>, HostHealthMonitor<H>, R)
    com.linkedin.davinci.client.AvroGenericDaVinciClient.getLatestValueSchema()
    com.linkedin.davinci.client.DelegatingAvroGenericDaVinciClient.getLatestValueSchema()
    com.linkedin.venice.client.store.AbstractAvroStoreClient.getLatestValueSchema()
    com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient.compute(Optional<ClientStats>, Optional<ClientStats>, long)
    com.linkedin.venice.client.store.AvroGenericReadComputeStoreClient.compute(Optional<ClientStats>, Optional<ClientStats>, AvroGenericReadComputeStoreClient, long)
    com.linkedin.venice.client.store.AvroGenericStoreClient.getKeySchema()
    This method is considered deprecated. Please use StoreSchemaFetcher.getKeySchema() to fetch key schema instead.
    com.linkedin.venice.client.store.AvroGenericStoreClient.getLatestValueSchema()
    This method is considered deprecated. Please use StoreSchemaFetcher.getLatestValueSchemaEntry() to fetch latest value schema instead.
    com.linkedin.venice.client.store.ClientConfig.defaultVsonGenericClientConfig(String)
    com.linkedin.venice.client.store.ClientConfig.isVsonClient()
    com.linkedin.venice.client.store.ClientConfig.setAlwaysOnDeserializerNumberOfThreads(int)
    com.linkedin.venice.client.store.ClientConfig.setAlwaysOnDeserializerQueueCapacity(int)
    com.linkedin.venice.client.store.ClientConfig.setMultiGetEnvelopeIterableImpl(AvroGenericDeserializer.IterableImpl)
    com.linkedin.venice.client.store.ClientConfig.setOnDemandDeserializerNumberOfRecordsPerThread(int)
    com.linkedin.venice.client.store.ClientConfig.setVsonClient(boolean)
    com.linkedin.venice.client.store.DelegatingStoreClient.getKeySchema()
    com.linkedin.venice.client.store.DelegatingStoreClient.getLatestValueSchema()
    com.linkedin.venice.controller.server.CreateVersion.uploadPushInfo(Admin)
    com.linkedin.venice.controllerapi.ControllerClient.constructClusterControllerClient(String, String)
    Use ControllerClientFactory.getControllerClient(java.lang.String, java.lang.String, java.util.Optional<com.linkedin.venice.security.SSLFactory>)
    com.linkedin.venice.controllerapi.ControllerClient.constructClusterControllerClient(String, String, Optional<SSLFactory>)
    Use ControllerClientFactory.getControllerClient(java.lang.String, java.lang.String, java.util.Optional<com.linkedin.venice.security.SSLFactory>)
    com.linkedin.venice.controllerapi.ControllerClient.discoverAndConstructControllerClient(String, String, Optional<SSLFactory>, int)
    Use ControllerClientFactory.discoverAndConstructControllerClient(java.lang.String, java.lang.String, java.util.Optional<com.linkedin.venice.security.SSLFactory>, int)
    com.linkedin.venice.controllerapi.ControllerClient.getStore(String, String, String)
    com.linkedin.venice.controllerapi.ControllerResponse.getExceptionType()
    com.linkedin.venice.controllerapi.D2ControllerClient.convertToSecureUrl(URL)
     
    com.linkedin.venice.controllerapi.D2ControllerClient.convertToSecureUrl(URL, int)
     
    com.linkedin.venice.controllerapi.D2ControllerClient.discoverCluster(String, String, String, int)
    com.linkedin.venice.controllerapi.JobStatusQueryResponse.getExtraDetails()
    Only used for JSON serialization purposes. Use JobStatusQueryResponse.getOptionalExtraDetails() instead.
    com.linkedin.venice.controllerapi.JobStatusQueryResponse.getStatusDetails()
    Only used for JSON serialization purposes. Use JobStatusQueryResponse.getOptionalExtraDetails() instead.
    com.linkedin.venice.fastclient.ClientConfig.ClientConfigBuilder.setVsonStore(boolean)
    com.linkedin.venice.fastclient.ClientConfig.isVsonStore()
    com.linkedin.venice.fastclient.DelegatingAvroStoreClient.getLatestValueSchema()
    com.linkedin.venice.fastclient.DispatchingAvroGenericStoreClient.getLatestValueSchema()
    com.linkedin.venice.helix.ResourceAssignment.containsResource(String)
    com.linkedin.venice.meta.Instance.getUrl()
    com.linkedin.venice.meta.Version.getTimestampMetadataVersionId()
    Use Version.getRmdVersionId() instead
    com.linkedin.venice.meta.Version.setLeaderFollowerModelEnabled(boolean)
    com.linkedin.venice.meta.Version.setTimestampMetadataVersionId(int)
    Use Version.setRmdVersionId(int) instead
    com.linkedin.venice.meta.ZKStore.isAccessControlled()
    The store level accessControlled flag is no longer valid to be used to skip ACL checks.
    com.linkedin.venice.meta.ZKStore.setAccessControlled(boolean)
    The store level accessControlled flag is no longer valid to be used to skip ACL checks.
    com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder.getFabricToExecutionStatusMap()
    com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.Builder.getMutableFabricToExecutionStatusMap()
    com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponse.getFabricToExecutionStatusMap()
    com.linkedin.venice.protocols.controller.AdminCommandExecutionStatusGrpcResponseOrBuilder.getFabricToExecutionStatusMap()
    com.linkedin.venice.protocols.controller.ControllerGrpcErrorType.valueOf(int)
    com.linkedin.venice.pubsub.adapter.kafka.producer.ApacheKafkaProducerAdapter.getNumberOfPartitions(String)
    com.linkedin.venice.pubsub.api.PubSubProducerAdapter.getNumberOfPartitions(String)
    com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.newVeniceExceptionAndTracking(String, RequestType, HttpResponseStatus, String)
    com.linkedin.venice.router.api.RouterExceptionAndTrackingUtils.newVeniceExceptionAndTracking(String, RequestType, HttpResponseStatus, String, RouterExceptionAndTrackingUtils.FailureType)
    com.linkedin.venice.samza.VeniceSystemFactory.createSystemProducer(String, String, String, Version.PushType, String, String, boolean, Config, Optional<SSLFactory>, Optional<String>)
    Left in to maintain backward compatibility
    com.linkedin.venice.samza.VeniceSystemFactory.createSystemProducer(String, String, String, Version.PushType, String, String, Config, Optional<SSLFactory>, Optional<String>)
    Left in to maintain backward compatibility
    com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter.convert(String)
    com.linkedin.venice.schema.writecompute.WriteComputeSchemaConverter.convert(Schema)
    com.linkedin.venice.utils.TestUtils.getParticipant(String, String, String, int, String)
    TODO: migrate to use ServiceFactory for generating a participant
    com.linkedin.venice.writer.VeniceWriter.put(KafkaKey, KafkaMessageEnvelope, PubSubProducerCallback, int, LeaderMetadataWrapper)
    io.netty.handler.codec.http2.EspressoHttp2StreamChannelBootstrap.open0(ChannelHandlerContext, Promise<Http2StreamChannel>, EventLoop)
    should not be used directly. Use EspressoHttp2StreamChannelBootstrap.open() or
  • Deprecated Constructors
    Constructor
    Description
    com.linkedin.alpini.base.misc.QueryStringDecoder(String, String)
    Use QueryStringDecoder(String, Charset) instead.
    com.linkedin.alpini.base.misc.QueryStringDecoder(URI, String)
    Use QueryStringDecoder(URI, Charset) instead.
    com.linkedin.alpini.netty4.handlers.StaleConnectionHandler(long, long, TimeUnit)
    com.linkedin.alpini.netty4.http2.Http2PipelineInitializer(Http2Settings, ActiveStreamsCountHandler, Http2SettingsFrameLogger, Consumer<ChannelPipeline>, int, int, int, boolean, boolean)
    com.linkedin.alpini.router.ScatterGatherRequestHandler4(ScatterGatherHelper<H, P, K, R, BasicFullHttpRequest, FullHttpResponse, HttpResponseStatus>, TimeoutProcessor, Executor)
    com.linkedin.davinci.client.factory.CachingDaVinciClientFactory(D2Client, MetricsRepository, VeniceProperties)
    com.linkedin.davinci.client.factory.CachingDaVinciClientFactory(D2Client, MetricsRepository, VeniceProperties, Optional<Set<String>>)
    com.linkedin.davinci.client.factory.CachingDaVinciClientFactory(D2Client, MetricsRepository, VeniceProperties, Optional<Set<String>>, ICProvider)
    com.linkedin.venice.controller.VeniceController(List<VeniceProperties>, MetricsRepository, List<ServiceDiscoveryAnnouncer>, Optional<DynamicAccessController>, Optional<AuthorizerService>, D2Client, Optional<ClientConfig>, Optional<ICProvider>, Optional<SupersetSchemaGenerator>)
    com.linkedin.venice.meta.VersionImpl(String, int)
    com.linkedin.venice.router.streaming.NettyChunkedWriteHandler(int)
    use NettyChunkedWriteHandler()
    com.linkedin.venice.samza.VeniceSystemProducer(String, String, String, Version.PushType, String, String, boolean, VeniceSystemFactory, Optional<SSLFactory>, Optional<String>)
    com.linkedin.venice.samza.VeniceSystemProducer(String, String, String, Version.PushType, String, String, boolean, VeniceSystemFactory, Optional<SSLFactory>, Optional<String>, Time)
    com.linkedin.venice.server.VeniceServer(VeniceConfigLoader, MetricsRepository, Optional<SSLFactory>, Optional<StaticAccessController>, Optional<DynamicAccessController>, Optional<ClientConfig>, ICProvider, List<ServiceDiscoveryAnnouncer>)
    Use VeniceServer(VeniceServerContext) instead. Constructor kept for maintaining the backward compatibility Allocates a new VeniceServer object.
    com.linkedin.venice.utils.VeniceProperties()
    Use VeniceProperties.empty()
    com.linkedin.venice.writer.VeniceWriterFactory(Properties, MetricsRepository)
  • Deprecated Enum Constants
    Enum Constant
    Description
    com.linkedin.davinci.kafka.consumer.KafkaConsumerService.ConsumerAssignmentStrategy.TOPIC_WISE_SHARED_CONSUMER_ASSIGNMENT_STRATEGY
    com.linkedin.venice.client.store.deserialization.BatchDeserializerType.ALWAYS_ON_MULTI_THREADED_PIPELINE
    com.linkedin.venice.client.store.deserialization.BatchDeserializerType.ONE_FUTURE_PER_RECORD
    com.linkedin.venice.compression.CompressionStrategy.ZSTD
    com.linkedin.venice.controller.kafka.protocol.enums.AdminMessageType.CONFIGURE_INCREMENTAL_PUSH_FOR_CLUSTER
    We do not support incremental push policy anymore.
    com.linkedin.venice.controllerapi.ControllerRoute.MASTER_CONTROLLER
    com.linkedin.venice.ingestion.protocol.enums.IngestionReportType.START_OF_BUFFER_REPLAY_RECEIVED
    com.linkedin.venice.kafka.protocol.enums.ControlMessageType.START_OF_BUFFER_REPLAY
    com.linkedin.venice.kafka.validation.checksum.CheckSumType.ADLER32
    com.linkedin.venice.kafka.validation.checksum.CheckSumType.CRC32
    com.linkedin.venice.meta.DataReplicationPolicy.ACTIVE_ACTIVE
    com.linkedin.venice.meta.DataReplicationPolicy.NONE
    com.linkedin.venice.PushJobCheckpoints.START_VALIDATE_SCHEMA_AND_BUILD_DICT_MAP_JOB
    com.linkedin.venice.PushJobCheckpoints.VALIDATE_SCHEMA_AND_BUILD_DICT_MAP_JOB_COMPLETED
    com.linkedin.venice.PushJobCheckpoints.ZSTD_DICTIONARY_CREATION_FAILED
    com.linkedin.venice.pushmonitor.ExecutionStatus.ARCHIVED
    com.linkedin.venice.pushmonitor.ExecutionStatus.DROPPED
    com.linkedin.venice.pushmonitor.ExecutionStatus.START_OF_BUFFER_REPLAY_RECEIVED
    com.linkedin.venice.pushmonitor.ExecutionStatus.WARNING
    com.linkedin.venice.router.api.RouterResourceType.TYPE_LEADER_CONTROLLER_LEGACY
    com.linkedin.venice.router.httpclient.StorageNodeClientType.APACHE_HTTP_ASYNC_CLIENT
    com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl.LAZY
    com.linkedin.venice.serializer.AvroGenericDeserializer.IterableImpl.LAZY_WITH_REPLAY_SUPPORT