java.lang.Object
org.apache.avro.specific.SpecificRecordBase
com.linkedin.venice.controller.kafka.protocol.admin.UpdateStore
All Implemented Interfaces:
Externalizable, Serializable, Comparable<org.apache.avro.specific.SpecificRecord>, org.apache.avro.generic.GenericContainer, org.apache.avro.generic.GenericRecord, org.apache.avro.generic.IndexedRecord, org.apache.avro.specific.SpecificRecord

public class UpdateStore extends org.apache.avro.specific.SpecificRecordBase implements org.apache.avro.specific.SpecificRecord
See Also:
  • Field Details

    • SCHEMA$

      public static final org.apache.avro.Schema SCHEMA$
    • clusterName

      public CharSequence clusterName
    • storeName

      public CharSequence storeName
    • owner

      public CharSequence owner
    • partitionNum

      public int partitionNum
    • currentVersion

      public int currentVersion
    • enableReads

      public boolean enableReads
    • enableWrites

      public boolean enableWrites
    • storageQuotaInByte

      public long storageQuotaInByte
    • readQuotaInCU

      public long readQuotaInCU
    • hybridStoreConfig

      public HybridStoreConfigRecord hybridStoreConfig
    • accessControlled

      public boolean accessControlled
    • compressionStrategy

      public int compressionStrategy
      Using int because Avro Enums are not evolvable
    • chunkingEnabled

      public boolean chunkingEnabled
    • rmdChunkingEnabled

      public boolean rmdChunkingEnabled
    • singleGetRouterCacheEnabled

      public boolean singleGetRouterCacheEnabled
    • batchGetRouterCacheEnabled

      public boolean batchGetRouterCacheEnabled
    • batchGetLimit

      public int batchGetLimit
      The max key number allowed in batch get request, and Venice will use cluster-level config if the limit (not positive) is not valid
    • numVersionsToPreserve

      public int numVersionsToPreserve
      The max number of versions the store should preserve. Venice will use cluster-level config if the number is 0 here.
    • incrementalPushEnabled

      public boolean incrementalPushEnabled
      a flag to see if the store supports incremental push or not
    • separateRealTimeTopicEnabled

      public boolean separateRealTimeTopicEnabled
      Flag to see if the store supports separate real-time topic for incremental push.
    • isMigrating

      public boolean isMigrating
      Whether or not the store is in the process of migration
    • writeComputationEnabled

      public boolean writeComputationEnabled
      Whether write-path computation feature is enabled for this store
    • replicationMetadataVersionID

      public int replicationMetadataVersionID
      RMD (Replication metadata) version ID on the store-level. Default -1 means NOT_SET and the cluster-level RMD version ID should be used for stores.
    • readComputationEnabled

      public boolean readComputationEnabled
      Whether read-path computation feature is enabled for this store
    • bootstrapToOnlineTimeoutInHours

      public int bootstrapToOnlineTimeoutInHours
      Maximum number of hours allowed for the store to transition from bootstrap to online state
    • leaderFollowerModelEnabled

      public boolean leaderFollowerModelEnabled
      Whether or not to use leader follower state transition model for upcoming version
    • backupStrategy

      public int backupStrategy
      Strategies to store backup versions.
    • clientDecompressionEnabled

      public boolean clientDecompressionEnabled
    • schemaAutoRegisterFromPushJobEnabled

      public boolean schemaAutoRegisterFromPushJobEnabled
    • hybridStoreOverheadBypass

      public boolean hybridStoreOverheadBypass
    • hybridStoreDiskQuotaEnabled

      public boolean hybridStoreDiskQuotaEnabled
      Whether or not to enable disk storage quota for a hybrid store
    • ETLStoreConfig

      public ETLStoreConfigRecord ETLStoreConfig
    • partitionerConfig

      public PartitionerConfigRecord partitionerConfig
    • nativeReplicationEnabled

      public boolean nativeReplicationEnabled
    • pushStreamSourceAddress

      public CharSequence pushStreamSourceAddress
    • largestUsedVersionNumber

      public Integer largestUsedVersionNumber
    • incrementalPushPolicy

      public int incrementalPushPolicy
      Incremental Push Policy to reconcile with real time pushes. Using int because Avro Enums are not evolvable 0 => PUSH_TO_VERSION_TOPIC, 1 => INCREMENTAL_PUSH_SAME_AS_REAL_TIME
    • backupVersionRetentionMs

      public long backupVersionRetentionMs
      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
    • replicationFactor

      public int replicationFactor
      number of replica each store version will have
    • migrationDuplicateStore

      public boolean migrationDuplicateStore
      Whether or not the store is a duplicate store in the process of migration
    • nativeReplicationSourceFabric

      public CharSequence nativeReplicationSourceFabric
      The source fabric to be used when the store is running in Native Replication mode.
    • activeActiveReplicationEnabled

      public boolean activeActiveReplicationEnabled
      A command option to enable/disable Active/Active replication feature for a store
    • disableMetaStore

      public boolean disableMetaStore
      An UpdateStore command option to disable the companion meta system store
    • disableDavinciPushStatusStore

      public boolean disableDavinciPushStatusStore
      An UpdateStore command option to disable the companion davinci push status store
    • applyTargetVersionFilterForIncPush

      public boolean applyTargetVersionFilterForIncPush
      An UpdateStore command option to enable/disable applying the target version filter for incremental pushes
    • updatedConfigsList

      public List<CharSequence> updatedConfigsList
      The list that contains all updated configs by the UpdateStore command. Most of the fields in UpdateStore are not optional, and changing those fields to Optional (Union) is not a backward compatible change, so we have to add an addition array field to record all updated configs in parent controller.
    • replicateAllConfigs

      public boolean replicateAllConfigs
      A flag to indicate whether all store configs in parent cluster will be replicated to child clusters; true by default, so that existing UpdateStore messages in Admin topic will behave the same as before.
    • regionsFilter

      public CharSequence regionsFilter
      A list of regions that will be impacted by the UpdateStore command
    • storagePersona

      public CharSequence storagePersona
      The name of the StoragePersona to add to the store
    • views

      A map of views which describe and configure a downstream view of a venice store. Keys in this map are for convenience of managing configs.
    • latestSuperSetValueSchemaId

      public int latestSuperSetValueSchemaId
      The schema id for the latest superset schema
    • storageNodeReadQuotaEnabled

      public boolean storageNodeReadQuotaEnabled
      Whether storage node read quota is enabled for this store
    • minCompactionLagSeconds

      public long minCompactionLagSeconds
      Store-level version topic min compaction lag
    • maxCompactionLagSeconds

      public long maxCompactionLagSeconds
      Store-level version topic max compaction lag
    • maxRecordSizeBytes

      public int maxRecordSizeBytes
      Store-level maximum size of any record in bytes for batch push jobs
    • maxNearlineRecordSizeBytes

      public int maxNearlineRecordSizeBytes
      Store-level maximum size of any record in bytes for nearline jobs with partial updates
    • unusedSchemaDeletionEnabled

      public boolean unusedSchemaDeletionEnabled
      Whether unused schema deletion is enabled or not.
    • blobTransferEnabled

      public boolean blobTransferEnabled
      Flag to indicate if the blob transfer is allowed or not
    • nearlineProducerCompressionEnabled

      public boolean nearlineProducerCompressionEnabled
      Flag to control whether the producer in Server for nearline workload will enable compression or not
    • nearlineProducerCountPerWriter

      public int nearlineProducerCountPerWriter
      How many producers will be used for the nearline producer in Server to improve producing throughput
    • targetSwapRegion

      public CharSequence targetSwapRegion
      Controls what region to swap in the current version during target colo push
    • targetSwapRegionWaitTime

      public int targetSwapRegionWaitTime
      Controls how long to wait in minutes before swapping the version on the regions
    • isDaVinciHeartBeatReported

      public boolean isDaVinciHeartBeatReported
      Flag to indicate whether DVC is bootstrapping and sending heartbeats
  • Constructor Details

    • UpdateStore

      public UpdateStore()
      Default constructor. Note that this does not initialize fields to their default values from the schema. If that is desired then one should use newBuilder().
    • UpdateStore

      public UpdateStore(CharSequence clusterName, CharSequence storeName, CharSequence owner, Integer partitionNum, Integer currentVersion, Boolean enableReads, Boolean enableWrites, Long storageQuotaInByte, Long readQuotaInCU, HybridStoreConfigRecord hybridStoreConfig, Boolean accessControlled, Integer compressionStrategy, Boolean chunkingEnabled, Boolean rmdChunkingEnabled, Boolean singleGetRouterCacheEnabled, Boolean batchGetRouterCacheEnabled, Integer batchGetLimit, Integer numVersionsToPreserve, Boolean incrementalPushEnabled, Boolean separateRealTimeTopicEnabled, Boolean isMigrating, Boolean writeComputationEnabled, Integer replicationMetadataVersionID, Boolean readComputationEnabled, Integer bootstrapToOnlineTimeoutInHours, Boolean leaderFollowerModelEnabled, Integer backupStrategy, Boolean clientDecompressionEnabled, Boolean schemaAutoRegisterFromPushJobEnabled, Boolean hybridStoreOverheadBypass, Boolean hybridStoreDiskQuotaEnabled, ETLStoreConfigRecord ETLStoreConfig, PartitionerConfigRecord partitionerConfig, Boolean nativeReplicationEnabled, CharSequence pushStreamSourceAddress, Integer largestUsedVersionNumber, Integer incrementalPushPolicy, Long backupVersionRetentionMs, Integer replicationFactor, Boolean migrationDuplicateStore, CharSequence nativeReplicationSourceFabric, Boolean activeActiveReplicationEnabled, Boolean disableMetaStore, Boolean disableDavinciPushStatusStore, Boolean applyTargetVersionFilterForIncPush, List<CharSequence> updatedConfigsList, Boolean replicateAllConfigs, CharSequence regionsFilter, CharSequence storagePersona, Map<String,StoreViewConfigRecord> views, Integer latestSuperSetValueSchemaId, Boolean storageNodeReadQuotaEnabled, Long minCompactionLagSeconds, Long maxCompactionLagSeconds, Integer maxRecordSizeBytes, Integer maxNearlineRecordSizeBytes, Boolean unusedSchemaDeletionEnabled, Boolean blobTransferEnabled, Boolean nearlineProducerCompressionEnabled, Integer nearlineProducerCountPerWriter, CharSequence targetSwapRegion, Integer targetSwapRegionWaitTime, Boolean isDaVinciHeartBeatReported)
      All-args constructor.
      Parameters:
      clusterName - The new value for clusterName
      storeName - The new value for storeName
      owner - The new value for owner
      partitionNum - The new value for partitionNum
      currentVersion - The new value for currentVersion
      enableReads - The new value for enableReads
      enableWrites - The new value for enableWrites
      storageQuotaInByte - The new value for storageQuotaInByte
      readQuotaInCU - The new value for readQuotaInCU
      hybridStoreConfig - The new value for hybridStoreConfig
      accessControlled - The new value for accessControlled
      compressionStrategy - Using int because Avro Enums are not evolvable
      chunkingEnabled - The new value for chunkingEnabled
      rmdChunkingEnabled - The new value for rmdChunkingEnabled
      singleGetRouterCacheEnabled - The new value for singleGetRouterCacheEnabled
      batchGetRouterCacheEnabled - The new value for batchGetRouterCacheEnabled
      batchGetLimit - The max key number allowed in batch get request, and Venice will use cluster-level config if the limit (not positive) is not valid
      numVersionsToPreserve - The max number of versions the store should preserve. Venice will use cluster-level config if the number is 0 here.
      incrementalPushEnabled - a flag to see if the store supports incremental push or not
      separateRealTimeTopicEnabled - Flag to see if the store supports separate real-time topic for incremental push.
      isMigrating - Whether or not the store is in the process of migration
      writeComputationEnabled - Whether write-path computation feature is enabled for this store
      replicationMetadataVersionID - RMD (Replication metadata) version ID on the store-level. Default -1 means NOT_SET and the cluster-level RMD version ID should be used for stores.
      readComputationEnabled - Whether read-path computation feature is enabled for this store
      bootstrapToOnlineTimeoutInHours - Maximum number of hours allowed for the store to transition from bootstrap to online state
      leaderFollowerModelEnabled - Whether or not to use leader follower state transition model for upcoming version
      backupStrategy - Strategies to store backup versions.
      clientDecompressionEnabled - The new value for clientDecompressionEnabled
      schemaAutoRegisterFromPushJobEnabled - The new value for schemaAutoRegisterFromPushJobEnabled
      hybridStoreOverheadBypass - The new value for hybridStoreOverheadBypass
      hybridStoreDiskQuotaEnabled - Whether or not to enable disk storage quota for a hybrid store
      ETLStoreConfig - The new value for ETLStoreConfig
      partitionerConfig - The new value for partitionerConfig
      nativeReplicationEnabled - The new value for nativeReplicationEnabled
      pushStreamSourceAddress - The new value for pushStreamSourceAddress
      largestUsedVersionNumber - The new value for largestUsedVersionNumber
      incrementalPushPolicy - Incremental Push Policy to reconcile with real time pushes. Using int because Avro Enums are not evolvable 0 => PUSH_TO_VERSION_TOPIC, 1 => INCREMENTAL_PUSH_SAME_AS_REAL_TIME
      backupVersionRetentionMs - 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
      replicationFactor - number of replica each store version will have
      migrationDuplicateStore - Whether or not the store is a duplicate store in the process of migration
      nativeReplicationSourceFabric - The source fabric to be used when the store is running in Native Replication mode.
      activeActiveReplicationEnabled - A command option to enable/disable Active/Active replication feature for a store
      disableMetaStore - An UpdateStore command option to disable the companion meta system store
      disableDavinciPushStatusStore - An UpdateStore command option to disable the companion davinci push status store
      applyTargetVersionFilterForIncPush - An UpdateStore command option to enable/disable applying the target version filter for incremental pushes
      updatedConfigsList - The list that contains all updated configs by the UpdateStore command. Most of the fields in UpdateStore are not optional, and changing those fields to Optional (Union) is not a backward compatible change, so we have to add an addition array field to record all updated configs in parent controller.
      replicateAllConfigs - A flag to indicate whether all store configs in parent cluster will be replicated to child clusters; true by default, so that existing UpdateStore messages in Admin topic will behave the same as before.
      regionsFilter - A list of regions that will be impacted by the UpdateStore command
      storagePersona - The name of the StoragePersona to add to the store
      views - A map of views which describe and configure a downstream view of a venice store. Keys in this map are for convenience of managing configs.
      latestSuperSetValueSchemaId - The schema id for the latest superset schema
      storageNodeReadQuotaEnabled - Whether storage node read quota is enabled for this store
      minCompactionLagSeconds - Store-level version topic min compaction lag
      maxCompactionLagSeconds - Store-level version topic max compaction lag
      maxRecordSizeBytes - Store-level maximum size of any record in bytes for batch push jobs
      maxNearlineRecordSizeBytes - Store-level maximum size of any record in bytes for nearline jobs with partial updates
      unusedSchemaDeletionEnabled - Whether unused schema deletion is enabled or not.
      blobTransferEnabled - Flag to indicate if the blob transfer is allowed or not
      nearlineProducerCompressionEnabled - Flag to control whether the producer in Server for nearline workload will enable compression or not
      nearlineProducerCountPerWriter - How many producers will be used for the nearline producer in Server to improve producing throughput
      targetSwapRegion - Controls what region to swap in the current version during target colo push
      targetSwapRegionWaitTime - Controls how long to wait in minutes before swapping the version on the regions
      isDaVinciHeartBeatReported - Flag to indicate whether DVC is bootstrapping and sending heartbeats
  • Method Details

    • getClassSchema

      public static org.apache.avro.Schema getClassSchema()
    • getSpecificData

      public org.apache.avro.specific.SpecificData getSpecificData()
      Overrides:
      getSpecificData in class org.apache.avro.specific.SpecificRecordBase
    • getSchema

      public org.apache.avro.Schema getSchema()
      Specified by:
      getSchema in interface org.apache.avro.generic.GenericContainer
      Specified by:
      getSchema in class org.apache.avro.specific.SpecificRecordBase
    • get

      public Object get(int field$)
      Specified by:
      get in interface org.apache.avro.generic.IndexedRecord
      Specified by:
      get in class org.apache.avro.specific.SpecificRecordBase
    • put

      public void put(int field$, Object value$)
      Specified by:
      put in interface org.apache.avro.generic.IndexedRecord
      Specified by:
      put in class org.apache.avro.specific.SpecificRecordBase
    • getClusterName

      public CharSequence getClusterName()
      Gets the value of the 'clusterName' field.
      Returns:
      The value of the 'clusterName' field.
    • setClusterName

      public void setClusterName(CharSequence value)
      Sets the value of the 'clusterName' field.
      Parameters:
      value - the value to set.
    • getStoreName

      public CharSequence getStoreName()
      Gets the value of the 'storeName' field.
      Returns:
      The value of the 'storeName' field.
    • setStoreName

      public void setStoreName(CharSequence value)
      Sets the value of the 'storeName' field.
      Parameters:
      value - the value to set.
    • getOwner

      public CharSequence getOwner()
      Gets the value of the 'owner' field.
      Returns:
      The value of the 'owner' field.
    • setOwner

      public void setOwner(CharSequence value)
      Sets the value of the 'owner' field.
      Parameters:
      value - the value to set.
    • getPartitionNum

      public int getPartitionNum()
      Gets the value of the 'partitionNum' field.
      Returns:
      The value of the 'partitionNum' field.
    • setPartitionNum

      public void setPartitionNum(int value)
      Sets the value of the 'partitionNum' field.
      Parameters:
      value - the value to set.
    • getCurrentVersion

      public int getCurrentVersion()
      Gets the value of the 'currentVersion' field.
      Returns:
      The value of the 'currentVersion' field.
    • setCurrentVersion

      public void setCurrentVersion(int value)
      Sets the value of the 'currentVersion' field.
      Parameters:
      value - the value to set.
    • getEnableReads

      public boolean getEnableReads()
      Gets the value of the 'enableReads' field.
      Returns:
      The value of the 'enableReads' field.
    • setEnableReads

      public void setEnableReads(boolean value)
      Sets the value of the 'enableReads' field.
      Parameters:
      value - the value to set.
    • getEnableWrites

      public boolean getEnableWrites()
      Gets the value of the 'enableWrites' field.
      Returns:
      The value of the 'enableWrites' field.
    • setEnableWrites

      public void setEnableWrites(boolean value)
      Sets the value of the 'enableWrites' field.
      Parameters:
      value - the value to set.
    • getStorageQuotaInByte

      public long getStorageQuotaInByte()
      Gets the value of the 'storageQuotaInByte' field.
      Returns:
      The value of the 'storageQuotaInByte' field.
    • setStorageQuotaInByte

      public void setStorageQuotaInByte(long value)
      Sets the value of the 'storageQuotaInByte' field.
      Parameters:
      value - the value to set.
    • getReadQuotaInCU

      public long getReadQuotaInCU()
      Gets the value of the 'readQuotaInCU' field.
      Returns:
      The value of the 'readQuotaInCU' field.
    • setReadQuotaInCU

      public void setReadQuotaInCU(long value)
      Sets the value of the 'readQuotaInCU' field.
      Parameters:
      value - the value to set.
    • getHybridStoreConfig

      public HybridStoreConfigRecord getHybridStoreConfig()
      Gets the value of the 'hybridStoreConfig' field.
      Returns:
      The value of the 'hybridStoreConfig' field.
    • setHybridStoreConfig

      public void setHybridStoreConfig(HybridStoreConfigRecord value)
      Sets the value of the 'hybridStoreConfig' field.
      Parameters:
      value - the value to set.
    • getAccessControlled

      public boolean getAccessControlled()
      Gets the value of the 'accessControlled' field.
      Returns:
      The value of the 'accessControlled' field.
    • setAccessControlled

      public void setAccessControlled(boolean value)
      Sets the value of the 'accessControlled' field.
      Parameters:
      value - the value to set.
    • getCompressionStrategy

      public int getCompressionStrategy()
      Gets the value of the 'compressionStrategy' field.
      Returns:
      Using int because Avro Enums are not evolvable
    • setCompressionStrategy

      public void setCompressionStrategy(int value)
      Sets the value of the 'compressionStrategy' field. Using int because Avro Enums are not evolvable
      Parameters:
      value - the value to set.
    • getChunkingEnabled

      public boolean getChunkingEnabled()
      Gets the value of the 'chunkingEnabled' field.
      Returns:
      The value of the 'chunkingEnabled' field.
    • setChunkingEnabled

      public void setChunkingEnabled(boolean value)
      Sets the value of the 'chunkingEnabled' field.
      Parameters:
      value - the value to set.
    • getRmdChunkingEnabled

      public boolean getRmdChunkingEnabled()
      Gets the value of the 'rmdChunkingEnabled' field.
      Returns:
      The value of the 'rmdChunkingEnabled' field.
    • setRmdChunkingEnabled

      public void setRmdChunkingEnabled(boolean value)
      Sets the value of the 'rmdChunkingEnabled' field.
      Parameters:
      value - the value to set.
    • getSingleGetRouterCacheEnabled

      public boolean getSingleGetRouterCacheEnabled()
      Gets the value of the 'singleGetRouterCacheEnabled' field.
      Returns:
      The value of the 'singleGetRouterCacheEnabled' field.
    • setSingleGetRouterCacheEnabled

      public void setSingleGetRouterCacheEnabled(boolean value)
      Sets the value of the 'singleGetRouterCacheEnabled' field.
      Parameters:
      value - the value to set.
    • getBatchGetRouterCacheEnabled

      public boolean getBatchGetRouterCacheEnabled()
      Gets the value of the 'batchGetRouterCacheEnabled' field.
      Returns:
      The value of the 'batchGetRouterCacheEnabled' field.
    • setBatchGetRouterCacheEnabled

      public void setBatchGetRouterCacheEnabled(boolean value)
      Sets the value of the 'batchGetRouterCacheEnabled' field.
      Parameters:
      value - the value to set.
    • getBatchGetLimit

      public int getBatchGetLimit()
      Gets the value of the 'batchGetLimit' field.
      Returns:
      The max key number allowed in batch get request, and Venice will use cluster-level config if the limit (not positive) is not valid
    • setBatchGetLimit

      public void setBatchGetLimit(int value)
      Sets the value of the 'batchGetLimit' field. The max key number allowed in batch get request, and Venice will use cluster-level config if the limit (not positive) is not valid
      Parameters:
      value - the value to set.
    • getNumVersionsToPreserve

      public int getNumVersionsToPreserve()
      Gets the value of the 'numVersionsToPreserve' field.
      Returns:
      The max number of versions the store should preserve. Venice will use cluster-level config if the number is 0 here.
    • setNumVersionsToPreserve

      public void setNumVersionsToPreserve(int value)
      Sets the value of the 'numVersionsToPreserve' field. The max number of versions the store should preserve. Venice will use cluster-level config if the number is 0 here.
      Parameters:
      value - the value to set.
    • getIncrementalPushEnabled

      public boolean getIncrementalPushEnabled()
      Gets the value of the 'incrementalPushEnabled' field.
      Returns:
      a flag to see if the store supports incremental push or not
    • setIncrementalPushEnabled

      public void setIncrementalPushEnabled(boolean value)
      Sets the value of the 'incrementalPushEnabled' field. a flag to see if the store supports incremental push or not
      Parameters:
      value - the value to set.
    • getSeparateRealTimeTopicEnabled

      public boolean getSeparateRealTimeTopicEnabled()
      Gets the value of the 'separateRealTimeTopicEnabled' field.
      Returns:
      Flag to see if the store supports separate real-time topic for incremental push.
    • setSeparateRealTimeTopicEnabled

      public void setSeparateRealTimeTopicEnabled(boolean value)
      Sets the value of the 'separateRealTimeTopicEnabled' field. Flag to see if the store supports separate real-time topic for incremental push.
      Parameters:
      value - the value to set.
    • getIsMigrating

      public boolean getIsMigrating()
      Gets the value of the 'isMigrating' field.
      Returns:
      Whether or not the store is in the process of migration
    • setIsMigrating

      public void setIsMigrating(boolean value)
      Sets the value of the 'isMigrating' field. Whether or not the store is in the process of migration
      Parameters:
      value - the value to set.
    • getWriteComputationEnabled

      public boolean getWriteComputationEnabled()
      Gets the value of the 'writeComputationEnabled' field.
      Returns:
      Whether write-path computation feature is enabled for this store
    • setWriteComputationEnabled

      public void setWriteComputationEnabled(boolean value)
      Sets the value of the 'writeComputationEnabled' field. Whether write-path computation feature is enabled for this store
      Parameters:
      value - the value to set.
    • getReplicationMetadataVersionID

      public int getReplicationMetadataVersionID()
      Gets the value of the 'replicationMetadataVersionID' field.
      Returns:
      RMD (Replication metadata) version ID on the store-level. Default -1 means NOT_SET and the cluster-level RMD version ID should be used for stores.
    • setReplicationMetadataVersionID

      public void setReplicationMetadataVersionID(int value)
      Sets the value of the 'replicationMetadataVersionID' field. RMD (Replication metadata) version ID on the store-level. Default -1 means NOT_SET and the cluster-level RMD version ID should be used for stores.
      Parameters:
      value - the value to set.
    • getReadComputationEnabled

      public boolean getReadComputationEnabled()
      Gets the value of the 'readComputationEnabled' field.
      Returns:
      Whether read-path computation feature is enabled for this store
    • setReadComputationEnabled

      public void setReadComputationEnabled(boolean value)
      Sets the value of the 'readComputationEnabled' field. Whether read-path computation feature is enabled for this store
      Parameters:
      value - the value to set.
    • getBootstrapToOnlineTimeoutInHours

      public int getBootstrapToOnlineTimeoutInHours()
      Gets the value of the 'bootstrapToOnlineTimeoutInHours' field.
      Returns:
      Maximum number of hours allowed for the store to transition from bootstrap to online state
    • setBootstrapToOnlineTimeoutInHours

      public void setBootstrapToOnlineTimeoutInHours(int value)
      Sets the value of the 'bootstrapToOnlineTimeoutInHours' field. Maximum number of hours allowed for the store to transition from bootstrap to online state
      Parameters:
      value - the value to set.
    • getLeaderFollowerModelEnabled

      public boolean getLeaderFollowerModelEnabled()
      Gets the value of the 'leaderFollowerModelEnabled' field.
      Returns:
      Whether or not to use leader follower state transition model for upcoming version
    • setLeaderFollowerModelEnabled

      public void setLeaderFollowerModelEnabled(boolean value)
      Sets the value of the 'leaderFollowerModelEnabled' field. Whether or not to use leader follower state transition model for upcoming version
      Parameters:
      value - the value to set.
    • getBackupStrategy

      public int getBackupStrategy()
      Gets the value of the 'backupStrategy' field.
      Returns:
      Strategies to store backup versions.
    • setBackupStrategy

      public void setBackupStrategy(int value)
      Sets the value of the 'backupStrategy' field. Strategies to store backup versions.
      Parameters:
      value - the value to set.
    • getClientDecompressionEnabled

      public boolean getClientDecompressionEnabled()
      Gets the value of the 'clientDecompressionEnabled' field.
      Returns:
      The value of the 'clientDecompressionEnabled' field.
    • setClientDecompressionEnabled

      public void setClientDecompressionEnabled(boolean value)
      Sets the value of the 'clientDecompressionEnabled' field.
      Parameters:
      value - the value to set.
    • getSchemaAutoRegisterFromPushJobEnabled

      public boolean getSchemaAutoRegisterFromPushJobEnabled()
      Gets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
      Returns:
      The value of the 'schemaAutoRegisterFromPushJobEnabled' field.
    • setSchemaAutoRegisterFromPushJobEnabled

      public void setSchemaAutoRegisterFromPushJobEnabled(boolean value)
      Sets the value of the 'schemaAutoRegisterFromPushJobEnabled' field.
      Parameters:
      value - the value to set.
    • getHybridStoreOverheadBypass

      public boolean getHybridStoreOverheadBypass()
      Gets the value of the 'hybridStoreOverheadBypass' field.
      Returns:
      The value of the 'hybridStoreOverheadBypass' field.
    • setHybridStoreOverheadBypass

      public void setHybridStoreOverheadBypass(boolean value)
      Sets the value of the 'hybridStoreOverheadBypass' field.
      Parameters:
      value - the value to set.
    • getHybridStoreDiskQuotaEnabled

      public boolean getHybridStoreDiskQuotaEnabled()
      Gets the value of the 'hybridStoreDiskQuotaEnabled' field.
      Returns:
      Whether or not to enable disk storage quota for a hybrid store
    • setHybridStoreDiskQuotaEnabled

      public void setHybridStoreDiskQuotaEnabled(boolean value)
      Sets the value of the 'hybridStoreDiskQuotaEnabled' field. Whether or not to enable disk storage quota for a hybrid store
      Parameters:
      value - the value to set.
    • getETLStoreConfig

      public ETLStoreConfigRecord getETLStoreConfig()
      Gets the value of the 'ETLStoreConfig' field.
      Returns:
      The value of the 'ETLStoreConfig' field.
    • setETLStoreConfig

      public void setETLStoreConfig(ETLStoreConfigRecord value)
      Sets the value of the 'ETLStoreConfig' field.
      Parameters:
      value - the value to set.
    • getPartitionerConfig

      public PartitionerConfigRecord getPartitionerConfig()
      Gets the value of the 'partitionerConfig' field.
      Returns:
      The value of the 'partitionerConfig' field.
    • setPartitionerConfig

      public void setPartitionerConfig(PartitionerConfigRecord value)
      Sets the value of the 'partitionerConfig' field.
      Parameters:
      value - the value to set.
    • getNativeReplicationEnabled

      public boolean getNativeReplicationEnabled()
      Gets the value of the 'nativeReplicationEnabled' field.
      Returns:
      The value of the 'nativeReplicationEnabled' field.
    • setNativeReplicationEnabled

      public void setNativeReplicationEnabled(boolean value)
      Sets the value of the 'nativeReplicationEnabled' field.
      Parameters:
      value - the value to set.
    • getPushStreamSourceAddress

      public CharSequence getPushStreamSourceAddress()
      Gets the value of the 'pushStreamSourceAddress' field.
      Returns:
      The value of the 'pushStreamSourceAddress' field.
    • setPushStreamSourceAddress

      public void setPushStreamSourceAddress(CharSequence value)
      Sets the value of the 'pushStreamSourceAddress' field.
      Parameters:
      value - the value to set.
    • getLargestUsedVersionNumber

      public Integer getLargestUsedVersionNumber()
      Gets the value of the 'largestUsedVersionNumber' field.
      Returns:
      The value of the 'largestUsedVersionNumber' field.
    • setLargestUsedVersionNumber

      public void setLargestUsedVersionNumber(Integer value)
      Sets the value of the 'largestUsedVersionNumber' field.
      Parameters:
      value - the value to set.
    • getIncrementalPushPolicy

      public int getIncrementalPushPolicy()
      Gets the value of the 'incrementalPushPolicy' field.
      Returns:
      Incremental Push Policy to reconcile with real time pushes. Using int because Avro Enums are not evolvable 0 => PUSH_TO_VERSION_TOPIC, 1 => INCREMENTAL_PUSH_SAME_AS_REAL_TIME
    • setIncrementalPushPolicy

      public void setIncrementalPushPolicy(int value)
      Sets the value of the 'incrementalPushPolicy' field. Incremental Push Policy to reconcile with real time pushes. Using int because Avro Enums are not evolvable 0 => PUSH_TO_VERSION_TOPIC, 1 => INCREMENTAL_PUSH_SAME_AS_REAL_TIME
      Parameters:
      value - the value to set.
    • getBackupVersionRetentionMs

      public long getBackupVersionRetentionMs()
      Gets the value of the 'backupVersionRetentionMs' field.
      Returns:
      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
    • setBackupVersionRetentionMs

      public void setBackupVersionRetentionMs(long value)
      Sets the value of the 'backupVersionRetentionMs' field. 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
      Parameters:
      value - the value to set.
    • getReplicationFactor

      public int getReplicationFactor()
      Gets the value of the 'replicationFactor' field.
      Returns:
      number of replica each store version will have
    • setReplicationFactor

      public void setReplicationFactor(int value)
      Sets the value of the 'replicationFactor' field. number of replica each store version will have
      Parameters:
      value - the value to set.
    • getMigrationDuplicateStore

      public boolean getMigrationDuplicateStore()
      Gets the value of the 'migrationDuplicateStore' field.
      Returns:
      Whether or not the store is a duplicate store in the process of migration
    • setMigrationDuplicateStore

      public void setMigrationDuplicateStore(boolean value)
      Sets the value of the 'migrationDuplicateStore' field. Whether or not the store is a duplicate store in the process of migration
      Parameters:
      value - the value to set.
    • getNativeReplicationSourceFabric

      public CharSequence getNativeReplicationSourceFabric()
      Gets the value of the 'nativeReplicationSourceFabric' field.
      Returns:
      The source fabric to be used when the store is running in Native Replication mode.
    • setNativeReplicationSourceFabric

      public void setNativeReplicationSourceFabric(CharSequence value)
      Sets the value of the 'nativeReplicationSourceFabric' field. The source fabric to be used when the store is running in Native Replication mode.
      Parameters:
      value - the value to set.
    • getActiveActiveReplicationEnabled

      public boolean getActiveActiveReplicationEnabled()
      Gets the value of the 'activeActiveReplicationEnabled' field.
      Returns:
      A command option to enable/disable Active/Active replication feature for a store
    • setActiveActiveReplicationEnabled

      public void setActiveActiveReplicationEnabled(boolean value)
      Sets the value of the 'activeActiveReplicationEnabled' field. A command option to enable/disable Active/Active replication feature for a store
      Parameters:
      value - the value to set.
    • getDisableMetaStore

      public boolean getDisableMetaStore()
      Gets the value of the 'disableMetaStore' field.
      Returns:
      An UpdateStore command option to disable the companion meta system store
    • setDisableMetaStore

      public void setDisableMetaStore(boolean value)
      Sets the value of the 'disableMetaStore' field. An UpdateStore command option to disable the companion meta system store
      Parameters:
      value - the value to set.
    • getDisableDavinciPushStatusStore

      public boolean getDisableDavinciPushStatusStore()
      Gets the value of the 'disableDavinciPushStatusStore' field.
      Returns:
      An UpdateStore command option to disable the companion davinci push status store
    • setDisableDavinciPushStatusStore

      public void setDisableDavinciPushStatusStore(boolean value)
      Sets the value of the 'disableDavinciPushStatusStore' field. An UpdateStore command option to disable the companion davinci push status store
      Parameters:
      value - the value to set.
    • getApplyTargetVersionFilterForIncPush

      public boolean getApplyTargetVersionFilterForIncPush()
      Gets the value of the 'applyTargetVersionFilterForIncPush' field.
      Returns:
      An UpdateStore command option to enable/disable applying the target version filter for incremental pushes
    • setApplyTargetVersionFilterForIncPush

      public void setApplyTargetVersionFilterForIncPush(boolean value)
      Sets the value of the 'applyTargetVersionFilterForIncPush' field. An UpdateStore command option to enable/disable applying the target version filter for incremental pushes
      Parameters:
      value - the value to set.
    • getUpdatedConfigsList

      public List<CharSequence> getUpdatedConfigsList()
      Gets the value of the 'updatedConfigsList' field.
      Returns:
      The list that contains all updated configs by the UpdateStore command. Most of the fields in UpdateStore are not optional, and changing those fields to Optional (Union) is not a backward compatible change, so we have to add an addition array field to record all updated configs in parent controller.
    • setUpdatedConfigsList

      public void setUpdatedConfigsList(List<CharSequence> value)
      Sets the value of the 'updatedConfigsList' field. The list that contains all updated configs by the UpdateStore command. Most of the fields in UpdateStore are not optional, and changing those fields to Optional (Union) is not a backward compatible change, so we have to add an addition array field to record all updated configs in parent controller.
      Parameters:
      value - the value to set.
    • getReplicateAllConfigs

      public boolean getReplicateAllConfigs()
      Gets the value of the 'replicateAllConfigs' field.
      Returns:
      A flag to indicate whether all store configs in parent cluster will be replicated to child clusters; true by default, so that existing UpdateStore messages in Admin topic will behave the same as before.
    • setReplicateAllConfigs

      public void setReplicateAllConfigs(boolean value)
      Sets the value of the 'replicateAllConfigs' field. A flag to indicate whether all store configs in parent cluster will be replicated to child clusters; true by default, so that existing UpdateStore messages in Admin topic will behave the same as before.
      Parameters:
      value - the value to set.
    • getRegionsFilter

      public CharSequence getRegionsFilter()
      Gets the value of the 'regionsFilter' field.
      Returns:
      A list of regions that will be impacted by the UpdateStore command
    • setRegionsFilter

      public void setRegionsFilter(CharSequence value)
      Sets the value of the 'regionsFilter' field. A list of regions that will be impacted by the UpdateStore command
      Parameters:
      value - the value to set.
    • getStoragePersona

      public CharSequence getStoragePersona()
      Gets the value of the 'storagePersona' field.
      Returns:
      The name of the StoragePersona to add to the store
    • setStoragePersona

      public void setStoragePersona(CharSequence value)
      Sets the value of the 'storagePersona' field. The name of the StoragePersona to add to the store
      Parameters:
      value - the value to set.
    • getViews

      public Map<String,StoreViewConfigRecord> getViews()
      Gets the value of the 'views' field.
      Returns:
      A map of views which describe and configure a downstream view of a venice store. Keys in this map are for convenience of managing configs.
    • setViews

      public void setViews(Map<String,StoreViewConfigRecord> value)
      Sets the value of the 'views' field. A map of views which describe and configure a downstream view of a venice store. Keys in this map are for convenience of managing configs.
      Parameters:
      value - the value to set.
    • getLatestSuperSetValueSchemaId

      public int getLatestSuperSetValueSchemaId()
      Gets the value of the 'latestSuperSetValueSchemaId' field.
      Returns:
      The schema id for the latest superset schema
    • setLatestSuperSetValueSchemaId

      public void setLatestSuperSetValueSchemaId(int value)
      Sets the value of the 'latestSuperSetValueSchemaId' field. The schema id for the latest superset schema
      Parameters:
      value - the value to set.
    • getStorageNodeReadQuotaEnabled

      public boolean getStorageNodeReadQuotaEnabled()
      Gets the value of the 'storageNodeReadQuotaEnabled' field.
      Returns:
      Whether storage node read quota is enabled for this store
    • setStorageNodeReadQuotaEnabled

      public void setStorageNodeReadQuotaEnabled(boolean value)
      Sets the value of the 'storageNodeReadQuotaEnabled' field. Whether storage node read quota is enabled for this store
      Parameters:
      value - the value to set.
    • getMinCompactionLagSeconds

      public long getMinCompactionLagSeconds()
      Gets the value of the 'minCompactionLagSeconds' field.
      Returns:
      Store-level version topic min compaction lag
    • setMinCompactionLagSeconds

      public void setMinCompactionLagSeconds(long value)
      Sets the value of the 'minCompactionLagSeconds' field. Store-level version topic min compaction lag
      Parameters:
      value - the value to set.
    • getMaxCompactionLagSeconds

      public long getMaxCompactionLagSeconds()
      Gets the value of the 'maxCompactionLagSeconds' field.
      Returns:
      Store-level version topic max compaction lag
    • setMaxCompactionLagSeconds

      public void setMaxCompactionLagSeconds(long value)
      Sets the value of the 'maxCompactionLagSeconds' field. Store-level version topic max compaction lag
      Parameters:
      value - the value to set.
    • getMaxRecordSizeBytes

      public int getMaxRecordSizeBytes()
      Gets the value of the 'maxRecordSizeBytes' field.
      Returns:
      Store-level maximum size of any record in bytes for batch push jobs
    • setMaxRecordSizeBytes

      public void setMaxRecordSizeBytes(int value)
      Sets the value of the 'maxRecordSizeBytes' field. Store-level maximum size of any record in bytes for batch push jobs
      Parameters:
      value - the value to set.
    • getMaxNearlineRecordSizeBytes

      public int getMaxNearlineRecordSizeBytes()
      Gets the value of the 'maxNearlineRecordSizeBytes' field.
      Returns:
      Store-level maximum size of any record in bytes for nearline jobs with partial updates
    • setMaxNearlineRecordSizeBytes

      public void setMaxNearlineRecordSizeBytes(int value)
      Sets the value of the 'maxNearlineRecordSizeBytes' field. Store-level maximum size of any record in bytes for nearline jobs with partial updates
      Parameters:
      value - the value to set.
    • getUnusedSchemaDeletionEnabled

      public boolean getUnusedSchemaDeletionEnabled()
      Gets the value of the 'unusedSchemaDeletionEnabled' field.
      Returns:
      Whether unused schema deletion is enabled or not.
    • setUnusedSchemaDeletionEnabled

      public void setUnusedSchemaDeletionEnabled(boolean value)
      Sets the value of the 'unusedSchemaDeletionEnabled' field. Whether unused schema deletion is enabled or not.
      Parameters:
      value - the value to set.
    • getBlobTransferEnabled

      public boolean getBlobTransferEnabled()
      Gets the value of the 'blobTransferEnabled' field.
      Returns:
      Flag to indicate if the blob transfer is allowed or not
    • setBlobTransferEnabled

      public void setBlobTransferEnabled(boolean value)
      Sets the value of the 'blobTransferEnabled' field. Flag to indicate if the blob transfer is allowed or not
      Parameters:
      value - the value to set.
    • getNearlineProducerCompressionEnabled

      public boolean getNearlineProducerCompressionEnabled()
      Gets the value of the 'nearlineProducerCompressionEnabled' field.
      Returns:
      Flag to control whether the producer in Server for nearline workload will enable compression or not
    • setNearlineProducerCompressionEnabled

      public void setNearlineProducerCompressionEnabled(boolean value)
      Sets the value of the 'nearlineProducerCompressionEnabled' field. Flag to control whether the producer in Server for nearline workload will enable compression or not
      Parameters:
      value - the value to set.
    • getNearlineProducerCountPerWriter

      public int getNearlineProducerCountPerWriter()
      Gets the value of the 'nearlineProducerCountPerWriter' field.
      Returns:
      How many producers will be used for the nearline producer in Server to improve producing throughput
    • setNearlineProducerCountPerWriter

      public void setNearlineProducerCountPerWriter(int value)
      Sets the value of the 'nearlineProducerCountPerWriter' field. How many producers will be used for the nearline producer in Server to improve producing throughput
      Parameters:
      value - the value to set.
    • getTargetSwapRegion

      public CharSequence getTargetSwapRegion()
      Gets the value of the 'targetSwapRegion' field.
      Returns:
      Controls what region to swap in the current version during target colo push
    • setTargetSwapRegion

      public void setTargetSwapRegion(CharSequence value)
      Sets the value of the 'targetSwapRegion' field. Controls what region to swap in the current version during target colo push
      Parameters:
      value - the value to set.
    • getTargetSwapRegionWaitTime

      public int getTargetSwapRegionWaitTime()
      Gets the value of the 'targetSwapRegionWaitTime' field.
      Returns:
      Controls how long to wait in minutes before swapping the version on the regions
    • setTargetSwapRegionWaitTime

      public void setTargetSwapRegionWaitTime(int value)
      Sets the value of the 'targetSwapRegionWaitTime' field. Controls how long to wait in minutes before swapping the version on the regions
      Parameters:
      value - the value to set.
    • getIsDaVinciHeartBeatReported

      public boolean getIsDaVinciHeartBeatReported()
      Gets the value of the 'isDaVinciHeartBeatReported' field.
      Returns:
      Flag to indicate whether DVC is bootstrapping and sending heartbeats
    • setIsDaVinciHeartBeatReported

      public void setIsDaVinciHeartBeatReported(boolean value)
      Sets the value of the 'isDaVinciHeartBeatReported' field. Flag to indicate whether DVC is bootstrapping and sending heartbeats
      Parameters:
      value - the value to set.
    • writeExternal

      public void writeExternal(ObjectOutput out) throws IOException
      Specified by:
      writeExternal in interface Externalizable
      Overrides:
      writeExternal in class org.apache.avro.specific.SpecificRecordBase
      Throws:
      IOException
    • readExternal

      public void readExternal(ObjectInput in) throws IOException
      Specified by:
      readExternal in interface Externalizable
      Overrides:
      readExternal in class org.apache.avro.specific.SpecificRecordBase
      Throws:
      IOException