Package com.linkedin.davinci.config
Class VeniceServerConfig
- java.lang.Object
-
- com.linkedin.davinci.config.VeniceClusterConfig
-
- com.linkedin.davinci.config.VeniceServerConfig
-
- Direct Known Subclasses:
VeniceStoreVersionConfig
public class VeniceServerConfig extends VeniceClusterConfig
VeniceServerConfig maintains configs specific to Venice Server, Da Vinci client and Isolated Ingestion Service.
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
VeniceServerConfig.IncrementalPushStatusWriteMode
-
Field Summary
Fields Modifier and Type Field Description static int
MINIMUM_CONSUMER_NUM_IN_CONSUMER_POOL_PER_KAFKA_CLUSTER
Since the RT topic could be consumed by multiple store versions for Hybrid stores, we couldn't share the consumer across different Hybrid store versions.
-
Constructor Summary
Constructors Constructor Description VeniceServerConfig(VeniceProperties serverProperties)
VeniceServerConfig(VeniceProperties serverProperties, java.util.Map<java.lang.String,java.util.Map<java.lang.String,java.lang.String>> kafkaClusterMap)
-
Method Summary
-
Methods inherited from class com.linkedin.davinci.config.VeniceClusterConfig
getClusterName, getClusterProperties, getEquivalentKafkaClusterIdForSepTopic, getKafkaBootstrapServers, getKafkaClusterAliasToIdMap, getKafkaClusterIdToAliasMap, getKafkaClusterIdToUrlMap, getKafkaClusterMap, getKafkaClusterUrlResolver, getKafkaClusterUrlToAliasMap, getKafkaClusterUrlToIdMap, getKafkaEmptyPollSleepMs, getKafkaFetchMaxSizePerSecond, getKafkaFetchMaxTimeMS, getKafkaFetchMinSizePerSecond, getKafkaFetchPartitionMaxSizePerSecond, getKafkaFetchQuotaBytesPerSecond, getKafkaFetchQuotaRecordPerSecond, getKafkaFetchQuotaTimeWindow, getKafkaFetchQuotaUnorderedBytesPerSecond, getKafkaFetchQuotaUnorderedRecordPerSecond, getKafkaReadCycleDelayMs, getKafkaSecurityProtocol, getPersistenceType, getRefreshAttemptsForZkReconnect, getRefreshIntervalForZkReconnectInMs, getRegionName, getRegionNames, getSslConfig, getZookeeperAddress
-
-
-
-
Field Detail
-
MINIMUM_CONSUMER_NUM_IN_CONSUMER_POOL_PER_KAFKA_CLUSTER
public static final int MINIMUM_CONSUMER_NUM_IN_CONSUMER_POOL_PER_KAFKA_CLUSTER
Since the RT topic could be consumed by multiple store versions for Hybrid stores, we couldn't share the consumer across different Hybrid store versions. Considering there will be at most 3 store versions (backup, current and new), we need to make sure the consumer pool size should be at least 3.- See Also:
- Constant Field Values
-
-
Constructor Detail
-
VeniceServerConfig
public VeniceServerConfig(VeniceProperties serverProperties) throws ConfigurationException
- Throws:
ConfigurationException
-
VeniceServerConfig
public VeniceServerConfig(VeniceProperties serverProperties, java.util.Map<java.lang.String,java.util.Map<java.lang.String,java.lang.String>> kafkaClusterMap) throws ConfigurationException
- Throws:
ConfigurationException
-
-
Method Detail
-
getListenerPort
public int getListenerPort()
-
getGrpcPort
public int getGrpcPort()
-
isGrpcEnabled
public boolean isGrpcEnabled()
-
getListenerHostname
public java.lang.String getListenerHostname()
-
getDvcP2pBlobTransferServerPort
public int getDvcP2pBlobTransferServerPort()
-
getDvcP2pBlobTransferClientPort
public int getDvcP2pBlobTransferClientPort()
-
isBlobTransferManagerEnabled
public boolean isBlobTransferManagerEnabled()
-
getMaxConcurrentSnapshotUser
public int getMaxConcurrentSnapshotUser()
-
getSnapshotRetentionTimeInMin
public int getSnapshotRetentionTimeInMin()
-
getDataBasePath
public java.lang.String getDataBasePath()
Get base path of Venice storage data.- Returns:
- Base path of persisted Venice database files.
-
isAutoCreateDataPath
public boolean isAutoCreateDataPath()
-
getRocksDBServerConfig
public RocksDBServerConfig getRocksDBServerConfig()
-
isServerAllowlistEnabled
public boolean isServerAllowlistEnabled()
-
getMaxLeaderFollowerStateTransitionThreadNumber
public int getMaxLeaderFollowerStateTransitionThreadNumber()
-
getMaxFutureVersionLeaderFollowerStateTransitionThreadNumber
public int getMaxFutureVersionLeaderFollowerStateTransitionThreadNumber()
-
getLeaderFollowerThreadPoolStrategy
public LeaderFollowerPartitionStateModelFactory.LeaderFollowerThreadPoolStrategy getLeaderFollowerThreadPoolStrategy()
-
getStoreWriterNumber
public int getStoreWriterNumber()
-
isStoreWriterBufferAfterLeaderLogicEnabled
public boolean isStoreWriterBufferAfterLeaderLogicEnabled()
-
getStoreWriterBufferMemoryCapacity
public long getStoreWriterBufferMemoryCapacity()
-
getStoreWriterBufferNotifyDelta
public long getStoreWriterBufferNotifyDelta()
-
getRestServiceStorageThreadNum
public int getRestServiceStorageThreadNum()
-
getServerComputeThreadNum
public int getServerComputeThreadNum()
-
getNettyIdleTimeInSeconds
public int getNettyIdleTimeInSeconds()
-
getMaxRequestSize
public int getMaxRequestSize()
-
getTopicOffsetCheckIntervalMs
public int getTopicOffsetCheckIntervalMs()
-
getNettyGracefulShutdownPeriodSeconds
public int getNettyGracefulShutdownPeriodSeconds()
-
getNettyWorkerThreadCount
public int getNettyWorkerThreadCount()
-
isHelixJoinAsUnknownEnabled
public boolean isHelixJoinAsUnknownEnabled()
-
getGrpcWorkerThreadCount
public int getGrpcWorkerThreadCount()
-
getDatabaseSyncBytesIntervalForTransactionalMode
public long getDatabaseSyncBytesIntervalForTransactionalMode()
-
getDatabaseSyncBytesIntervalForDeferredWriteMode
public long getDatabaseSyncBytesIntervalForDeferredWriteMode()
-
getDiskFullThreshold
public double getDiskFullThreshold()
-
getPartitionGracefulDropDelaySeconds
public int getPartitionGracefulDropDelaySeconds()
-
getStopConsumptionTimeoutInSeconds
public int getStopConsumptionTimeoutInSeconds()
-
getLeakedResourceCleanUpIntervalInMS
public long getLeakedResourceCleanUpIntervalInMS()
-
isQuotaEnforcementEnabled
public boolean isQuotaEnforcementEnabled()
-
isServerCalculateQuotaUsageBasedOnPartitionsAssignmentEnabled
public boolean isServerCalculateQuotaUsageBasedOnPartitionsAssignmentEnabled()
-
getNodeCapacityInRcu
public long getNodeCapacityInRcu()
-
getKafkaMaxPollRecords
public int getKafkaMaxPollRecords()
-
getPubSubConsumerPollRetryTimes
public int getPubSubConsumerPollRetryTimes()
-
getPubSubConsumerPollRetryBackoffMs
public int getPubSubConsumerPollRetryBackoffMs()
-
getDiskHealthCheckIntervalInMS
public long getDiskHealthCheckIntervalInMS()
-
getDiskHealthCheckTimeoutInMs
public long getDiskHealthCheckTimeoutInMs()
-
isDiskHealthCheckServiceEnabled
public boolean isDiskHealthCheckServiceEnabled()
-
getServerMaxWaitForVersionInfo
public java.time.Duration getServerMaxWaitForVersionInfo()
-
getBlockingQueueType
public BlockingQueueType getBlockingQueueType()
-
isComputeFastAvroEnabled
public boolean isComputeFastAvroEnabled()
-
getParticipantMessageConsumptionDelayMs
public long getParticipantMessageConsumptionDelayMs()
-
getServerPromotionToLeaderReplicaDelayMs
public long getServerPromotionToLeaderReplicaDelayMs()
-
getServerSystemStorePromotionToLeaderReplicaDelayMs
public long getServerSystemStorePromotionToLeaderReplicaDelayMs()
-
isHybridQuotaEnabled
public boolean isHybridQuotaEnabled()
-
isEnableParallelBatchGet
public boolean isEnableParallelBatchGet()
-
getParallelBatchGetChunkSize
public int getParallelBatchGetChunkSize()
-
isKeyValueProfilingEnabled
public boolean isKeyValueProfilingEnabled()
-
isDatabaseMemoryStatsEnabled
public boolean isDatabaseMemoryStatsEnabled()
-
getStoreToEarlyTerminationThresholdMSMap
public java.util.Map<java.lang.String,java.lang.Integer> getStoreToEarlyTerminationThresholdMSMap()
-
getDatabaseLookupQueueCapacity
public int getDatabaseLookupQueueCapacity()
-
getComputeQueueCapacity
public int getComputeQueueCapacity()
-
isRestServiceEpollEnabled
public boolean isRestServiceEpollEnabled()
-
getKafkaAdminClass
public java.lang.String getKafkaAdminClass()
-
getKafkaWriteOnlyClass
public java.lang.String getKafkaWriteOnlyClass()
-
getKafkaReadOnlyClass
public java.lang.String getKafkaReadOnlyClass()
-
getRouterConnectionWarmingDelayMs
public long getRouterConnectionWarmingDelayMs()
-
isHelixHybridStoreQuotaEnabled
public boolean isHelixHybridStoreQuotaEnabled()
-
getSsdHealthCheckShutdownTimeMs
public long getSsdHealthCheckShutdownTimeMs()
-
getSharedConsumerAssignmentStrategy
public KafkaConsumerService.ConsumerAssignmentStrategy getSharedConsumerAssignmentStrategy()
-
getConsumerPoolSizePerKafkaCluster
public int getConsumerPoolSizePerKafkaCluster()
-
isLeakedResourceCleanupEnabled
public boolean isLeakedResourceCleanupEnabled()
-
getIngestionMode
public IngestionMode getIngestionMode()
-
getIngestionServicePort
public int getIngestionServicePort()
-
getIngestionApplicationPort
public int getIngestionApplicationPort()
-
isDatabaseChecksumVerificationEnabled
public boolean isDatabaseChecksumVerificationEnabled()
-
getKafkaConsumerConfigsForLocalConsumption
public VeniceProperties getKafkaConsumerConfigsForLocalConsumption()
-
getKafkaConsumerConfigsForRemoteConsumption
public VeniceProperties getKafkaConsumerConfigsForRemoteConsumption()
-
isRocksDbStorageEngineConfigCheckEnabled
public boolean isRocksDbStorageEngineConfigCheckEnabled()
-
freezeIngestionIfReadyToServeOrLocalDataExists
public boolean freezeIngestionIfReadyToServeOrLocalDataExists()
-
getSystemSchemaClusterName
public java.lang.String getSystemSchemaClusterName()
-
getSharedConsumerNonExistingTopicCleanupDelayMS
public long getSharedConsumerNonExistingTopicCleanupDelayMS()
-
isDaVinciClient
public boolean isDaVinciClient()
-
isUnsubscribeAfterBatchpushEnabled
public boolean isUnsubscribeAfterBatchpushEnabled()
-
isHttp2InboundEnabled
public boolean isHttp2InboundEnabled()
-
getHttp2MaxConcurrentStreams
public int getHttp2MaxConcurrentStreams()
-
getHttp2MaxFrameSize
public int getHttp2MaxFrameSize()
-
getHttp2InitialWindowSize
public int getHttp2InitialWindowSize()
-
getHttp2HeaderTableSize
public int getHttp2HeaderTableSize()
-
getHttp2MaxHeaderListSize
public int getHttp2MaxHeaderListSize()
-
getOffsetLagDeltaRelaxFactorForFastOnlineTransitionInRestart
public int getOffsetLagDeltaRelaxFactorForFastOnlineTransitionInRestart()
-
isKafkaConsumerOffsetCollectionEnabled
public boolean isKafkaConsumerOffsetCollectionEnabled()
-
isDedicatedDrainerQueueEnabled
public boolean isDedicatedDrainerQueueEnabled()
-
getDrainerPoolSizeSortedInput
public int getDrainerPoolSizeSortedInput()
-
getDrainerPoolSizeUnsortedInput
public int getDrainerPoolSizeUnsortedInput()
-
isDebugLoggingEnabled
public boolean isDebugLoggingEnabled()
-
getNumSchemaFastClassWarmup
public int getNumSchemaFastClassWarmup()
-
getFastClassSchemaWarmupTimeout
public long getFastClassSchemaWarmupTimeout()
-
isSchemaPresenceCheckEnabled
public boolean isSchemaPresenceCheckEnabled()
-
isSystemSchemaInitializationAtStartTimeEnabled
public boolean isSystemSchemaInitializationAtStartTimeEnabled()
-
getLocalControllerUrl
public java.lang.String getLocalControllerUrl()
-
getLocalControllerD2ServiceName
public java.lang.String getLocalControllerD2ServiceName()
-
getLocalD2ZkHost
public java.lang.String getLocalD2ZkHost()
-
isLiveConfigBasedKafkaThrottlingEnabled
public boolean isLiveConfigBasedKafkaThrottlingEnabled()
-
isServerIngestionCheckpointDuringGracefulShutdownEnabled
public boolean isServerIngestionCheckpointDuringGracefulShutdownEnabled()
-
getRemoteIngestionRepairSleepInterval
public int getRemoteIngestionRepairSleepInterval()
-
isOptimizeDatabaseForBackupVersionEnabled
public boolean isOptimizeDatabaseForBackupVersionEnabled()
-
getOptimizeDatabaseForBackupVersionNoReadThresholdMS
public long getOptimizeDatabaseForBackupVersionNoReadThresholdMS()
-
getOptimizeDatabaseServiceScheduleIntervalSeconds
public long getOptimizeDatabaseServiceScheduleIntervalSeconds()
-
isUnregisterMetricForDeletedStoreEnabled
public boolean isUnregisterMetricForDeletedStoreEnabled()
-
isReadOnlyForBatchOnlyStoreEnabled
public boolean isReadOnlyForBatchOnlyStoreEnabled()
-
getFastAvroFieldLimitPerMethod
public int getFastAvroFieldLimitPerMethod()
-
getSslHandshakeThreadPoolSize
public int getSslHandshakeThreadPoolSize()
-
getSslHandshakeQueueCapacity
public int getSslHandshakeQueueCapacity()
-
getIngestionMemoryLimit
public long getIngestionMemoryLimit()
-
getForkedProcessJvmArgList
public java.util.List<java.lang.String> getForkedProcessJvmArgList()
-
isIngestionMlockEnabled
public boolean isIngestionMlockEnabled()
-
enforceMemoryLimitInStore
public boolean enforceMemoryLimitInStore(java.lang.String storeName)
-
getDivProducerStateMaxAgeMs
public long getDivProducerStateMaxAgeMs()
-
getPubSubClientsFactory
public PubSubClientsFactory getPubSubClientsFactory()
-
getRouterPrincipalName
public java.lang.String getRouterPrincipalName()
-
getIngestionTaskMaxIdleCount
public int getIngestionTaskMaxIdleCount()
-
isKMERegistrationFromMessageHeaderEnabled
public boolean isKMERegistrationFromMessageHeaderEnabled()
-
getMetaStoreWriterCloseTimeoutInMS
public long getMetaStoreWriterCloseTimeoutInMS()
-
getMetaStoreWriterCloseConcurrency
public int getMetaStoreWriterCloseConcurrency()
-
getIngestionHeartbeatIntervalMs
public long getIngestionHeartbeatIntervalMs()
-
getBatchReportEOIPEnabled
public boolean getBatchReportEOIPEnabled()
-
extractIncPushStatusWriteMode
public VeniceServerConfig.IncrementalPushStatusWriteMode extractIncPushStatusWriteMode(java.lang.String mode)
-
getIncrementalPushStatusWriteMode
public VeniceServerConfig.IncrementalPushStatusWriteMode getIncrementalPushStatusWriteMode()
-
isLeaderCompleteStateCheckInFollowerEnabled
public boolean isLeaderCompleteStateCheckInFollowerEnabled()
-
getLeaderCompleteStateCheckInFollowerValidIntervalMs
public long getLeaderCompleteStateCheckInFollowerValidIntervalMs()
-
isStuckConsumerRepairEnabled
public boolean isStuckConsumerRepairEnabled()
-
getStuckConsumerRepairIntervalSecond
public int getStuckConsumerRepairIntervalSecond()
-
getStuckConsumerDetectionRepairThresholdSecond
public int getStuckConsumerDetectionRepairThresholdSecond()
-
getNonExistingTopicIngestionTaskKillThresholdSecond
public int getNonExistingTopicIngestionTaskKillThresholdSecond()
-
getNonExistingTopicCheckRetryIntervalSecond
public int getNonExistingTopicCheckRetryIntervalSecond()
-
isDedicatedConsumerPoolForAAWCLeaderEnabled
public boolean isDedicatedConsumerPoolForAAWCLeaderEnabled()
-
getDedicatedConsumerPoolSizeForAAWCLeader
public int getDedicatedConsumerPoolSizeForAAWCLeader()
-
getConsumerPoolStrategyType
public KafkaConsumerServiceDelegator.ConsumerPoolStrategyType getConsumerPoolStrategyType()
-
getConsumerPoolSizeForCurrentVersionAAWCLeader
public int getConsumerPoolSizeForCurrentVersionAAWCLeader()
-
getConsumerPoolSizeForNonCurrentVersionAAWCLeader
public int getConsumerPoolSizeForNonCurrentVersionAAWCLeader()
-
getConsumerPoolSizeForCurrentVersionNonAAWCLeader
public int getConsumerPoolSizeForCurrentVersionNonAAWCLeader()
-
getConsumerPoolSizeForNonCurrentVersionNonAAWCLeader
public int getConsumerPoolSizeForNonCurrentVersionNonAAWCLeader()
-
getTopicManagerMetadataFetcherConsumerPoolSize
public int getTopicManagerMetadataFetcherConsumerPoolSize()
-
getTopicManagerMetadataFetcherThreadPoolSize
public int getTopicManagerMetadataFetcherThreadPoolSize()
-
useDaVinciSpecificExecutionStatusForError
public boolean useDaVinciSpecificExecutionStatusForError()
-
getDaVinciPushStatusCheckIntervalInMs
public long getDaVinciPushStatusCheckIntervalInMs()
-
isRecordLevelMetricWhenBootstrappingCurrentVersionEnabled
public boolean isRecordLevelMetricWhenBootstrappingCurrentVersionEnabled()
-
getIdentityParserClassName
public java.lang.String getIdentityParserClassName()
-
getDefaultMaxRecordSizeBytes
public int getDefaultMaxRecordSizeBytes()
-
getRocksDBPath
public java.lang.String getRocksDBPath()
-
isDaVinciCurrentVersionBootstrappingSpeedupEnabled
public boolean isDaVinciCurrentVersionBootstrappingSpeedupEnabled()
-
getDaVinciCurrentVersionBootstrappingQuotaRecordsPerSecond
public long getDaVinciCurrentVersionBootstrappingQuotaRecordsPerSecond()
-
getDaVinciCurrentVersionBootstrappingQuotaBytesPerSecond
public long getDaVinciCurrentVersionBootstrappingQuotaBytesPerSecond()
-
isResubscriptionTriggeredByVersionIngestionContextChangeEnabled
public boolean isResubscriptionTriggeredByVersionIngestionContextChangeEnabled()
-
getAaWCLeaderQuotaRecordsPerSecond
public int getAaWCLeaderQuotaRecordsPerSecond()
-
getCurrentVersionAAWCLeaderQuotaRecordsPerSecond
public int getCurrentVersionAAWCLeaderQuotaRecordsPerSecond()
-
getCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond
public int getCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond()
-
getNonCurrentVersionAAWCLeaderQuotaRecordsPerSecond
public int getNonCurrentVersionAAWCLeaderQuotaRecordsPerSecond()
-
getNonCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond
public int getNonCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond()
-
getChannelOptionWriteBufferHighBytes
public int getChannelOptionWriteBufferHighBytes()
-
getStoreVersionQpsRateLimiterType
public VeniceRateLimiter.RateLimiterType getStoreVersionQpsRateLimiterType()
-
getStorageNodeRateLimiterType
public VeniceRateLimiter.RateLimiterType getStorageNodeRateLimiterType()
-
getQuotaEnforcementIntervalInMs
public int getQuotaEnforcementIntervalInMs()
-
getQuotaEnforcementCapacityMultiple
public int getQuotaEnforcementCapacityMultiple()
-
isAAWCWorkloadParallelProcessingEnabled
public boolean isAAWCWorkloadParallelProcessingEnabled()
-
getAAWCWorkloadParallelProcessingThreadPoolSize
public int getAAWCWorkloadParallelProcessingThreadPoolSize()
-
isGlobalRtDivEnabled
public boolean isGlobalRtDivEnabled()
-
isNearlineWorkloadProducerThroughputOptimizationEnabled
public boolean isNearlineWorkloadProducerThroughputOptimizationEnabled()
-
getZstdDictCompressionLevel
public int getZstdDictCompressionLevel()
-
-