Package com.linkedin.davinci.config
Class VeniceServerConfig
java.lang.Object
com.linkedin.davinci.config.VeniceClusterConfig
com.linkedin.davinci.config.VeniceServerConfig
- Direct Known Subclasses:
VeniceStoreVersionConfig
VeniceServerConfig maintains configs specific to Venice Server, Da Vinci client and Isolated Ingestion Service.
-
Nested Class Summary
-
Field Summary
Modifier and TypeFieldDescriptionstatic final int
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.protected final boolean
-
Constructor Summary
ConstructorDescriptionVeniceServerConfig
(VeniceProperties serverProperties) VeniceServerConfig
(VeniceProperties serverProperties, Map<String, Map<String, String>> kafkaClusterMap) -
Method Summary
Modifier and TypeMethodDescriptionboolean
enforceMemoryLimitInStore
(String storeName) boolean
int
int
int
double
boolean
long
int
int
int
int
int
int
int
int
int
int
int
int
int
Get base path of Venice storage data.long
long
long
long
long
int
int
double
long
long
long
int
int
int
int
int
long
int
int
int
int
int
int
int
int
long
long
int
int
int
long
long
int
int
int
int
int
long
int
long
int
int
int
long
int
int
int
int
int
int
long
long
int
long
int
int
int
int
int
int
int
long
int
long
long
long
int
long
int
int
int
long
long
int
int
int
int
int
int
int
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
boolean
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 Details
-
MINIMUM_CONSUMER_NUM_IN_CONSUMER_POOL_PER_KAFKA_CLUSTER
public static final int MINIMUM_CONSUMER_NUM_IN_CONSUMER_POOL_PER_KAFKA_CLUSTERSince 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:
-
readOnlyForBatchOnlyStoreEnabled
protected final boolean readOnlyForBatchOnlyStoreEnabled
-
-
Constructor Details
-
VeniceServerConfig
- Throws:
ConfigurationException
-
VeniceServerConfig
public VeniceServerConfig(VeniceProperties serverProperties, Map<String, Map<String, throws ConfigurationExceptionString>> kafkaClusterMap) - Throws:
ConfigurationException
-
-
Method Details
-
getListenerPort
public int getListenerPort() -
getGrpcPort
public int getGrpcPort() -
isGrpcEnabled
public boolean isGrpcEnabled() -
getListenerHostname
-
getDvcP2pBlobTransferServerPort
public int getDvcP2pBlobTransferServerPort() -
getDvcP2pBlobTransferClientPort
public int getDvcP2pBlobTransferClientPort() -
isBlobTransferManagerEnabled
public boolean isBlobTransferManagerEnabled() -
getMaxConcurrentSnapshotUser
public int getMaxConcurrentSnapshotUser() -
getSnapshotRetentionTimeInMin
public int getSnapshotRetentionTimeInMin() -
getBlobTransferMaxTimeoutInMin
public int getBlobTransferMaxTimeoutInMin() -
getBlobTransferDisabledOffsetLagThreshold
public long getBlobTransferDisabledOffsetLagThreshold() -
getDataBasePath
Get base path of Venice storage data.- Returns:
- Base path of persisted Venice database files.
-
isAutoCreateDataPath
public boolean isAutoCreateDataPath() -
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
-
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
-
getDatabaseLookupQueueCapacity
public int getDatabaseLookupQueueCapacity() -
getComputeQueueCapacity
public int getComputeQueueCapacity() -
isRestServiceEpollEnabled
public boolean isRestServiceEpollEnabled() -
getKafkaAdminClass
-
getKafkaWriteOnlyClass
-
getKafkaReadOnlyClass
-
getRouterConnectionWarmingDelayMs
public long getRouterConnectionWarmingDelayMs() -
isHelixHybridStoreQuotaEnabled
public boolean isHelixHybridStoreQuotaEnabled() -
getSsdHealthCheckShutdownTimeMs
public long getSsdHealthCheckShutdownTimeMs() -
getConsumerPoolSizePerKafkaCluster
public int getConsumerPoolSizePerKafkaCluster() -
isLeakedResourceCleanupEnabled
public boolean isLeakedResourceCleanupEnabled() -
getIngestionMode
-
getIngestionServicePort
public int getIngestionServicePort() -
getIngestionApplicationPort
public int getIngestionApplicationPort() -
isDatabaseChecksumVerificationEnabled
public boolean isDatabaseChecksumVerificationEnabled() -
getKafkaConsumerConfigsForLocalConsumption
-
getKafkaConsumerConfigsForRemoteConsumption
-
isRocksDbStorageEngineConfigCheckEnabled
public boolean isRocksDbStorageEngineConfigCheckEnabled() -
freezeIngestionIfReadyToServeOrLocalDataExists
public boolean freezeIngestionIfReadyToServeOrLocalDataExists() -
getSystemSchemaClusterName
-
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
-
getLocalControllerD2ServiceName
-
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() -
isResetErrorReplicaEnabled
public boolean isResetErrorReplicaEnabled() -
isAdaptiveThrottlerEnabled
public boolean isAdaptiveThrottlerEnabled() -
getAdaptiveThrottlerSignalIdleThreshold
public int getAdaptiveThrottlerSignalIdleThreshold() -
getAdaptiveThrottlerSingleGetLatencyThreshold
public double getAdaptiveThrottlerSingleGetLatencyThreshold() -
getFastAvroFieldLimitPerMethod
public int getFastAvroFieldLimitPerMethod() -
getSslHandshakeThreadPoolSize
public int getSslHandshakeThreadPoolSize() -
getSslHandshakeQueueCapacity
public int getSslHandshakeQueueCapacity() -
getIngestionMemoryLimit
public long getIngestionMemoryLimit() -
getForkedProcessJvmArgList
-
isIngestionMlockEnabled
public boolean isIngestionMlockEnabled() -
enforceMemoryLimitInStore
-
getDivProducerStateMaxAgeMs
public long getDivProducerStateMaxAgeMs() -
getPubSubClientsFactory
-
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
-
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
-
getConsumerPoolSizeForCurrentVersionAAWCLeader
public int getConsumerPoolSizeForCurrentVersionAAWCLeader() -
getConsumerPoolSizeForCurrentVersionSepRTLeader
public int getConsumerPoolSizeForCurrentVersionSepRTLeader() -
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
-
getDefaultMaxRecordSizeBytes
public int getDefaultMaxRecordSizeBytes() -
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() -
getCurrentVersionSepRTLeaderQuotaRecordsPerSecond
public int getCurrentVersionSepRTLeaderQuotaRecordsPerSecond() -
getCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond
public int getCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond() -
getNonCurrentVersionAAWCLeaderQuotaRecordsPerSecond
public int getNonCurrentVersionAAWCLeaderQuotaRecordsPerSecond() -
getNonCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond
public int getNonCurrentVersionNonAAWCLeaderQuotaRecordsPerSecond() -
getChannelOptionWriteBufferHighBytes
public int getChannelOptionWriteBufferHighBytes() -
getStoreVersionQpsRateLimiterType
-
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() -
getMaxWaitAfterUnsubscribeMs
public long getMaxWaitAfterUnsubscribeMs() -
isDeleteUnassignedPartitionsOnStartupEnabled
public boolean isDeleteUnassignedPartitionsOnStartupEnabled()
-