Uses of Class
voldemort.store.StoreDefinition

Packages that use StoreDefinition
voldemort.client The user facing interface to Voldemort. 
voldemort.client.protocol.admin Classes that abstract admin based Voldemort requests. 
voldemort.client.rebalance All classes associated with the rebalance controller tool. 
voldemort.rest   
voldemort.rest.coordinator   
voldemort.rest.server   
voldemort.routing Routing strategies for mapping requests into the Voldemort cluster. 
voldemort.server.protocol.admin Server side implementation of admin based requests 
voldemort.server.rebalance Classes dealing with rebalancing on the server side. 
voldemort.server.storage The storage service which handles instantiating all the stores and their corresponding engines. 
voldemort.store The Store interface is the primary interface for Voldemort. 
voldemort.store.bdb A storage engine that persists data in BDB JE. 
voldemort.store.configuration A storage engine to persist metadata on a server. 
voldemort.store.memory An in-memory storage engine that serves data out of a non-persistent map. 
voldemort.store.metadata Our in-memory metadata store on the server which is backed by the configuration files. 
voldemort.store.mysql A storage engine that persists data in a mysql instance. 
voldemort.store.readonly A storage engine that provides very efficient read-only access to large sorted files of data. 
voldemort.store.retention   
voldemort.store.routed A store implmentation that handles routing to nodes, and repairing obsolete values detected on those nodes. 
voldemort.store.slop.strategy Bunch of different ways in which we would store failed requests for the Hinted handoff feature. 
voldemort.store.system   
voldemort.store.views Classes related to Views and server side transforms 
voldemort.tools Tools used for administrating a cluster. 
voldemort.tools.admin   
voldemort.tools.admin.command   
voldemort.utils Basic helper functions. 
voldemort.xml Classes related to parsing our metadata ( cluster + store definition ) 
 

Uses of StoreDefinition in voldemort.client
 

Methods in voldemort.client that return types with arguments of type StoreDefinition
 java.util.List<StoreDefinition> AbstractStoreClientFactory.getStoreDefs()
           
 

Uses of StoreDefinition in voldemort.client.protocol.admin
 

Methods in voldemort.client.protocol.admin that return types with arguments of type StoreDefinition
 java.util.List<StoreDefinition> AdminClient.RebalancingOperations.getCurrentStoreDefinitions(Cluster cluster)
          Given the cluster metadata, retrieves the list of store definitions.
 Versioned<java.util.List<StoreDefinition>> AdminClient.MetadataManagementOperations.getRemoteStoreDefList()
           
 Versioned<java.util.List<StoreDefinition>> AdminClient.MetadataManagementOperations.getRemoteStoreDefList(int nodeId)
          Retrieve the store definitions from a remote node.
 java.util.List<StoreDefinition> AdminClient.HelperOperations.getStoresInCluster()
           
 

Methods in voldemort.client.protocol.admin with parameters of type StoreDefinition
 void AdminClient.StoreManagementOperations.addStore(StoreDefinition def)
          Add a new store definition to all active nodes in the cluster.
 void AdminClient.StoreManagementOperations.addStore(StoreDefinition def, java.util.Collection<java.lang.Integer> nodeIds)
           
 void AdminClient.StoreManagementOperations.addStore(StoreDefinition def, int nodeId)
          Add a new store definition to a particular node
 java.util.Map<java.lang.Integer,java.util.List<java.lang.Integer>> AdminClient.ReplicationOperations.getReplicationMapping(int restoringNode, Cluster cluster, StoreDefinition storeDef)
          For a particular node, finds out all the [replica, partition] tuples it needs to steal in order to be brought back to normal state
 java.util.Map<java.lang.Integer,java.util.List<java.lang.Integer>> AdminClient.ReplicationOperations.getReplicationMapping(int restoringNode, Cluster cluster, StoreDefinition storeDef, int zoneId)
          For a particular node, finds out all the [node, partition] it needs to steal in order to be brought back to normal state
 

Method parameters in voldemort.client.protocol.admin with type arguments of type StoreDefinition
 void AdminClient.MetadataManagementOperations.fetchAndUpdateRemoteStore(int nodeId, java.util.List<StoreDefinition> updatedStores)
          Helper method to fetch the current stores xml list and update the specified stores
 void AdminClient.MetadataManagementOperations.fetchAndUpdateRemoteStores(java.util.List<StoreDefinition> updatedStores)
          Helper method to fetch the current stores xml list and update the specified stores.
 void AdminClient.RebalancingOperations.rebalanceStateChange(Cluster existingCluster, Cluster transitionCluster, java.util.List<StoreDefinition> existingStoreDefs, java.util.List<StoreDefinition> targetStoreDefs, java.util.List<RebalanceTaskInfo> rebalanceTaskPlanList, boolean swapRO, boolean changeClusterMetadata, boolean changeRebalanceState, boolean rollback, boolean failEarly)
          Used in rebalancing to indicate change in states.
 void AdminClient.RebalancingOperations.rebalanceStateChange(Cluster existingCluster, Cluster transitionCluster, java.util.List<StoreDefinition> existingStoreDefs, java.util.List<StoreDefinition> targetStoreDefs, java.util.List<RebalanceTaskInfo> rebalanceTaskPlanList, boolean swapRO, boolean changeClusterMetadata, boolean changeRebalanceState, boolean rollback, boolean failEarly)
          Used in rebalancing to indicate change in states.
 void AdminClient.MetadataManagementOperations.updateRemoteStoreDefList(int nodeId, java.util.List<StoreDefinition> storesList)
          Update the store definitions on a remote node.
 void AdminClient.MetadataManagementOperations.updateRemoteStoreDefList(java.util.List<StoreDefinition> storesList)
          Wrapper for updateRemoteStoreDefList : update this for all the nodes
 void AdminClient.RebalancingOperations.validateReadOnlyStores(Cluster cluster, java.util.List<StoreDefinition> storeDefs)
          Given a list of store definitions, cluster and admin client returns a boolean indicating if all RO stores are in the correct format.
 

Uses of StoreDefinition in voldemort.client.rebalance
 

Methods in voldemort.client.rebalance that return types with arguments of type StoreDefinition
 java.util.List<StoreDefinition> RebalanceController.getCurrentStoreDefs()
           
 java.util.List<StoreDefinition> RebalanceBatchPlan.getCurrentStoreDefs()
           
 java.util.List<StoreDefinition> RebalancePlan.getCurrentStores()
           
 java.util.List<StoreDefinition> RebalanceBatchPlan.getFinalStoreDefs()
           
 java.util.List<StoreDefinition> RebalancePlan.getFinalStores()
           
 

Method parameters in voldemort.client.rebalance with type arguments of type StoreDefinition
 RebalancePlan RebalanceController.getPlan(Cluster finalCluster, java.util.List<StoreDefinition> finalStoreDefs, int batchSize)
          Construct a plan for the specified final cluster/stores & batchSize given the current cluster/stores & configuration of the RebalanceController.
 

Constructor parameters in voldemort.client.rebalance with type arguments of type StoreDefinition
RebalanceBatchPlan(Cluster currentCluster, Cluster finalCluster, java.util.List<StoreDefinition> commonStoreDefs)
          Develops a batch plan to go from current cluster to final cluster for given stores.
RebalanceBatchPlan(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster finalCluster, java.util.List<StoreDefinition> finalStoreDefs)
          Develops a batch plan to go from current cluster/stores to final cluster/stores.
RebalanceBatchPlan(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster finalCluster, java.util.List<StoreDefinition> finalStoreDefs)
          Develops a batch plan to go from current cluster/stores to final cluster/stores.
RebalancePlan(Cluster currentCluster, java.util.List<StoreDefinition> currentStores, Cluster finalCluster, int batchSize, java.lang.String outputDir)
           
RebalancePlan(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster finalCluster, java.util.List<StoreDefinition> finalStoreDefs, int batchSize, java.lang.String outputDir)
          Constructs a plan for the specified change from currentCluster/StoreDefs to finalCluster/StoreDefs.
RebalancePlan(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster finalCluster, java.util.List<StoreDefinition> finalStoreDefs, int batchSize, java.lang.String outputDir)
          Constructs a plan for the specified change from currentCluster/StoreDefs to finalCluster/StoreDefs.
 

Uses of StoreDefinition in voldemort.rest
 

Methods in voldemort.rest with parameters of type StoreDefinition
static java.lang.String RestUtils.constructSerializerInfoXml(StoreDefinition storeDefinition)
          Given a storedefinition, constructs the xml string to be sent out in response to a "schemata" fetch request
 

Uses of StoreDefinition in voldemort.rest.coordinator
 

Methods in voldemort.rest.coordinator that return types with arguments of type StoreDefinition
 java.util.List<StoreDefinition> CoordinatorMetadata.getStoresDefs()
           
 

Method parameters in voldemort.rest.coordinator with type arguments of type StoreDefinition
 void CoordinatorMetadata.setMetadata(java.lang.String clusterXml, java.util.List<StoreDefinition> storeDefList)
           
 

Constructor parameters in voldemort.rest.coordinator with type arguments of type StoreDefinition
CoordinatorMetadata(java.lang.String clusterXml, java.util.List<StoreDefinition> storeDefList)
           
 

Uses of StoreDefinition in voldemort.rest.server
 

Method parameters in voldemort.rest.server with type arguments of type StoreDefinition
 void RestPipelineFactory.createAndRegisterMBeansForAllStoreStats(VoldemortConfig config, java.util.List<StoreDefinition> storeDefinitions)
           
 

Constructor parameters in voldemort.rest.server with type arguments of type StoreDefinition
RestPipelineFactory(StoreRepository storeRepository, VoldemortConfig config, int localZoneId, java.util.List<StoreDefinition> storeDefinitions, org.jboss.netty.channel.group.ChannelGroup allchannels)
           
RestService(VoldemortConfig config, int restPort, StoreRepository storeRepository, int zoneId, java.util.List<StoreDefinition> storeDefinitions)
           
 

Uses of StoreDefinition in voldemort.routing
 

Methods in voldemort.routing that return StoreDefinition
 StoreDefinition BaseStoreRoutingPlan.getStoreDefinition()
           
 StoreDefinition StoreRoutingPlan.getStoreDefinition()
           
 

Methods in voldemort.routing with parameters of type StoreDefinition
static boolean StoreRoutingPlan.checkKeyBelongsToNode(byte[] key, int nodeId, Cluster cluster, StoreDefinition storeDef)
           
static java.util.List<java.lang.Integer> StoreRoutingPlan.checkKeyBelongsToPartition(byte[] key, java.util.Set<Pair<java.lang.Integer,java.util.HashMap<java.lang.Integer,java.util.List<java.lang.Integer>>>> stealerNodeToMappingTuples, Cluster cluster, StoreDefinition storeDef)
          Given a key and a list of steal infos give back a list of stealer node ids which will steal this.
static boolean StoreRoutingPlan.checkKeyBelongsToPartition(int nodeId, byte[] key, java.util.HashMap<java.lang.Integer,java.util.List<java.lang.Integer>> replicaToPartitionList, Cluster cluster, StoreDefinition storeDef)
          Check that the key belongs to one of the partitions in the map of replica type to partitions
static boolean StoreRoutingPlan.checkPartitionBelongsToNode(int partition, int nodeId, Cluster cluster, StoreDefinition storeDef)
          Checks if a given partition is stored in the node.
 RoutingStrategy RoutingStrategyFactory.updateRoutingStrategy(StoreDefinition storeDef, Cluster cluster)
           
 

Constructors in voldemort.routing with parameters of type StoreDefinition
BaseStoreRoutingPlan(Cluster cluster, StoreDefinition storeDefinition)
           
StoreRoutingPlan(Cluster cluster, StoreDefinition storeDefinition)
           
 

Uses of StoreDefinition in voldemort.server.protocol.admin
 

Fields in voldemort.server.protocol.admin declared as StoreDefinition
protected  StoreDefinition FetchStreamRequestHandler.storeDef
           
 

Uses of StoreDefinition in voldemort.server.rebalance
 

Method parameters in voldemort.server.rebalance with type arguments of type StoreDefinition
 void Rebalancer.rebalanceStateChange(Cluster cluster, java.util.List<StoreDefinition> storeDefs, java.util.List<RebalanceTaskInfo> rebalanceTaskInfo, boolean swapRO, boolean changeClusterAndStoresMetadata, boolean changeRebalanceState, boolean rollback)
          Support four different stages
For normal operation:
 

Uses of StoreDefinition in voldemort.server.storage
 

Methods in voldemort.server.storage with parameters of type StoreDefinition
protected  boolean DataMaintenanceJob.isWritableStore(StoreDefinition storeDef)
           
 StorageEngine<ByteArray,byte[],byte[]> StorageService.openStore(StoreDefinition storeDef)
           
 void StorageService.openSystemStore(StoreDefinition storeDef)
           
 void StorageService.registerEngine(StorageEngine<ByteArray,byte[],byte[]> engine, boolean isReadOnly, java.lang.String storeType, StoreDefinition storeDef)
          Register the given engine with the storage repository
 void StorageService.registerNodeStores(StoreDefinition def, Cluster cluster, int localNode)
          For server side routing create NodeStore (socketstore) and pass it on to a RebootstrappingStore.
 void StorageService.updateStore(StoreDefinition storeDef)
           
 

Method parameters in voldemort.server.storage with type arguments of type StoreDefinition
protected  void StorageService.initializeMetadataVersions(java.util.List<StoreDefinition> storeDefs)
           
 

Uses of StoreDefinition in voldemort.store
 

Methods in voldemort.store that return StoreDefinition
 StoreDefinition StoreDefinitionBuilder.build()
           
static StoreDefinition StoreUtils.getStoreDef(java.util.List<StoreDefinition> list, java.lang.String name)
          Get a store definition from the given list of store definitions
 

Methods in voldemort.store that return types with arguments of type StoreDefinition
static java.util.HashMap<java.lang.String,StoreDefinition> StoreUtils.getStoreDefsAsMap(java.util.List<StoreDefinition> storeDefs)
           
 

Methods in voldemort.store with parameters of type StoreDefinition
 StorageEngine<ByteArray,byte[],byte[]> StorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
          Get an initialized storage implementation
 void StorageConfiguration.update(StoreDefinition storeDef)
          Update the storage configuration at runtime
 

Method parameters in voldemort.store with type arguments of type StoreDefinition
static StoreDefinition StoreUtils.getStoreDef(java.util.List<StoreDefinition> list, java.lang.String name)
          Get a store definition from the given list of store definitions
static java.util.HashMap<java.lang.String,StoreDefinition> StoreUtils.getStoreDefsAsMap(java.util.List<StoreDefinition> storeDefs)
           
static java.util.List<java.lang.String> StoreUtils.getStoreNames(java.util.List<StoreDefinition> list, boolean ignoreViews)
          Get the list of store names from a list of store definitions
 

Uses of StoreDefinition in voldemort.store.bdb
 

Methods in voldemort.store.bdb with parameters of type StoreDefinition
 com.sleepycat.je.Environment BdbStorageConfiguration.getEnvironment(StoreDefinition storeDef)
           
 StorageEngine<ByteArray,byte[],byte[]> BdbStorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
           
 void BdbStorageConfiguration.update(StoreDefinition storeDef)
          Detect what has changed in the store definition and rewire BDB environments accordingly.
 

Uses of StoreDefinition in voldemort.store.configuration
 

Methods in voldemort.store.configuration with parameters of type StoreDefinition
 StorageEngine<ByteArray,byte[],byte[]> FileBackedCachingStorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
           
 void FileBackedCachingStorageConfiguration.update(StoreDefinition storeDef)
           
 

Uses of StoreDefinition in voldemort.store.memory
 

Methods in voldemort.store.memory with parameters of type StoreDefinition
 StorageEngine<ByteArray,byte[],byte[]> InMemoryStorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
           
 StorageEngine<ByteArray,byte[],byte[]> CacheStorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
           
 void InMemoryStorageConfiguration.update(StoreDefinition storeDef)
           
 void CacheStorageConfiguration.update(StoreDefinition storeDef)
           
 

Uses of StoreDefinition in voldemort.store.metadata
 

Methods in voldemort.store.metadata that return StoreDefinition
 StoreDefinition MetadataStore.getStoreDef(java.lang.String storeName)
           
 

Methods in voldemort.store.metadata that return types with arguments of type StoreDefinition
 java.util.List<StoreDefinition> MetadataStore.getRebalancingSourceStores()
           
 java.util.List<StoreDefinition> MetadataStore.getStoreDefList()
           
 java.util.List<StoreDefinition> MetadataStore.getSystemStoreDefList()
           
 

Methods in voldemort.store.metadata with parameters of type StoreDefinition
 void MetadataStore.addStoreDefinition(StoreDefinition storeDef)
          Function to add a new Store to the Metadata store.
 void MetadataStoreListener.updateStoreDefinition(StoreDefinition storeDef)
           
 

Uses of StoreDefinition in voldemort.store.mysql
 

Methods in voldemort.store.mysql with parameters of type StoreDefinition
 StorageEngine<ByteArray,byte[],byte[]> MysqlStorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
           
 void MysqlStorageConfiguration.update(StoreDefinition storeDef)
           
 

Uses of StoreDefinition in voldemort.store.readonly
 

Methods in voldemort.store.readonly with parameters of type StoreDefinition
 StorageEngine<ByteArray,byte[],byte[]> ReadOnlyStorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
           
 void ReadOnlyStorageConfiguration.update(StoreDefinition storeDef)
           
 

Constructors in voldemort.store.readonly with parameters of type StoreDefinition
JsonStoreBuilder(JsonReader reader, Cluster cluster, StoreDefinition storeDefinition, RoutingStrategy routingStrategy, java.io.File outputDir, java.io.File tempDir, int internalSortSize, int numThreads, int numChunks, int ioBufferSize, boolean gzipIntermediate)
           
 

Uses of StoreDefinition in voldemort.store.retention
 

Methods in voldemort.store.retention with parameters of type StoreDefinition
 void RetentionEnforcingStore.updateStoreDefinition(StoreDefinition storeDef)
          Updates the store definition object and the retention time based on the updated store definition
 

Constructors in voldemort.store.retention with parameters of type StoreDefinition
RetentionEnforcingStore(Store<ByteArray,byte[],byte[]> innerStore, StoreDefinition storeDef, boolean deleteExpiredEntries, Time time)
           
 

Uses of StoreDefinition in voldemort.store.routed
 

Fields in voldemort.store.routed declared as StoreDefinition
protected  StoreDefinition RoutedStore.storeDef
           
 

Methods in voldemort.store.routed with parameters of type StoreDefinition
 RoutedStore RoutedStoreFactory.create(Cluster cluster, StoreDefinition storeDefinition, java.util.Map<java.lang.Integer,Store<ByteArray,byte[],byte[]>> nodeStores, FailureDetector failureDetector, RoutedStoreConfig routedStoreConfig)
           
 RoutedStore RoutedStoreFactory.create(Cluster cluster, StoreDefinition storeDefinition, java.util.Map<java.lang.Integer,Store<ByteArray,byte[],byte[]>> nodeStores, java.util.Map<java.lang.Integer,NonblockingStore> nonblockingStores, java.util.Map<java.lang.Integer,Store<ByteArray,Slop,byte[]>> slopStores, java.util.Map<java.lang.Integer,NonblockingStore> nonblockingSlopStores, FailureDetector failureDetector, RoutedStoreConfig routedStoreConfig)
           
 

Constructors in voldemort.store.routed with parameters of type StoreDefinition
PipelineRoutedStore(java.util.Map<java.lang.Integer,Store<ByteArray,byte[],byte[]>> innerStores, java.util.Map<java.lang.Integer,NonblockingStore> nonblockingStores, java.util.Map<java.lang.Integer,Store<ByteArray,Slop,byte[]>> slopStores, java.util.Map<java.lang.Integer,NonblockingStore> nonblockingSlopStores, Cluster cluster, StoreDefinition storeDef, FailureDetector failureDetector, boolean repairReads, TimeoutConfig timeoutConfig, int clientZoneId, boolean isJmxEnabled, java.lang.String identifierString, ZoneAffinity zoneAffinity)
          Create a PipelineRoutedStore
RoutedStore(java.lang.String name, java.util.Map<java.lang.Integer,Store<ByteArray,byte[],byte[]>> innerStores, Cluster cluster, StoreDefinition storeDef, boolean repairReads, TimeoutConfig timeoutConfig, FailureDetector failureDetector, Time time)
           
ThreadPoolRoutedStore(java.lang.String name, java.util.Map<java.lang.Integer,Store<ByteArray,byte[],byte[]>> innerStores, Cluster cluster, StoreDefinition storeDef, boolean repairReads, java.util.concurrent.ExecutorService threadPool, TimeoutConfig timeoutConfig, FailureDetector failureDetector, Time time)
          Deprecated. Create a RoutedStoreClient
ThreadPoolRoutedStore(java.lang.String name, java.util.Map<java.lang.Integer,Store<ByteArray,byte[],byte[]>> innerStores, Cluster cluster, StoreDefinition storeDef, int numberOfThreads, boolean repairReads, TimeoutConfig timeoutConfig, FailureDetector failureDetector)
          Deprecated. Create a RoutedStoreClient
 

Uses of StoreDefinition in voldemort.store.slop.strategy
 

Methods in voldemort.store.slop.strategy with parameters of type StoreDefinition
 HintedHandoffStrategy HintedHandoffStrategyFactory.updateHintedHandoffStrategy(StoreDefinition storeDef, Cluster cluster)
           
 

Uses of StoreDefinition in voldemort.store.system
 

Methods in voldemort.store.system that return StoreDefinition
static StoreDefinition SystemStoreConstants.getSystemStoreDef(java.lang.String name)
           
 

Methods in voldemort.store.system that return types with arguments of type StoreDefinition
static java.util.List<StoreDefinition> SystemStoreConstants.getAllSystemStoreDefs()
           
 

Uses of StoreDefinition in voldemort.store.views
 

Methods in voldemort.store.views with parameters of type StoreDefinition
 StorageEngine<ByteArray,byte[],byte[]> ViewStorageConfiguration.getStore(StoreDefinition storeDef, RoutingStrategy strategy)
           
 void ViewStorageConfiguration.update(StoreDefinition storeDef)
           
 

Constructor parameters in voldemort.store.views with type arguments of type StoreDefinition
ViewStorageConfiguration(VoldemortConfig config, java.util.List<StoreDefinition> stores, StoreRepository repo)
           
 

Uses of StoreDefinition in voldemort.tools
 

Methods in voldemort.tools with parameters of type StoreDefinition
 boolean KeyVersionFetcherCLI.sampleStore(StoreDefinition storeDefinition)
           
 boolean KeySamplerCLI.sampleStore(StoreDefinition storeDefinition)
           
 

Method parameters in voldemort.tools with type arguments of type StoreDefinition
static Cluster Repartitioner.greedyShufflePartitions(Cluster nextCandidateCluster, int greedyAttempts, int greedySwapMaxPartitionsPerNode, int greedySwapMaxPartitionsPerZone, java.util.List<java.lang.Integer> greedySwapZoneIds, java.util.List<StoreDefinition> storeDefs)
          Within a single zone, tries swapping some minimum number of random partitions per node with some minimum number of random partitions from other nodes within the zone.
static Cluster Repartitioner.randomShufflePartitions(Cluster nextCandidateCluster, int randomSwapAttempts, int randomSwapSuccesses, java.util.List<java.lang.Integer> randomSwapZoneIds, java.util.List<StoreDefinition> storeDefs)
          Randomly shuffle partitions between nodes within every zone.
static Cluster Repartitioner.repartition(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster interimCluster, java.util.List<StoreDefinition> finalStoreDefs, java.lang.String outputDir, int attempts, boolean disableNodeBalancing, boolean disableZoneBalancing, boolean enableRandomSwaps, int randomSwapAttempts, int randomSwapSuccesses, java.util.List<java.lang.Integer> randomSwapZoneIds, boolean enableGreedySwaps, int greedySwapAttempts, int greedySwapMaxPartitionsPerNode, int greedySwapMaxPartitionsPerZone, java.util.List<java.lang.Integer> greedySwapZoneIds, int maxContiguousPartitionsPerZone)
          Runs a number of distinct algorithms over the specified clusters/store defs to better balance partition IDs over nodes such that all nodes have similar iops and capacity usage.
static Cluster Repartitioner.repartition(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster interimCluster, java.util.List<StoreDefinition> finalStoreDefs, java.lang.String outputDir, int attempts, boolean disableNodeBalancing, boolean disableZoneBalancing, boolean enableRandomSwaps, int randomSwapAttempts, int randomSwapSuccesses, java.util.List<java.lang.Integer> randomSwapZoneIds, boolean enableGreedySwaps, int greedySwapAttempts, int greedySwapMaxPartitionsPerNode, int greedySwapMaxPartitionsPerZone, java.util.List<java.lang.Integer> greedySwapZoneIds, int maxContiguousPartitionsPerZone)
          Runs a number of distinct algorithms over the specified clusters/store defs to better balance partition IDs over nodes such that all nodes have similar iops and capacity usage.
static Cluster Repartitioner.swapGreedyRandomPartitions(Cluster nextCandidateCluster, java.util.List<java.lang.Integer> nodeIds, int greedySwapMaxPartitionsPerNode, int greedySwapMaxPartitionsPerZone, java.util.List<StoreDefinition> storeDefs)
          For each node in specified zones, tries swapping some minimum number of random partitions per node with some minimum number of random partitions from other specified nodes.
 

Constructors in voldemort.tools with parameters of type StoreDefinition
KeySamplerCLI.SampleNodeTask(Node node, StoreDefinition storeDefinition, java.io.Writer writer)
           
 

Constructor parameters in voldemort.tools with type arguments of type StoreDefinition
PartitionBalance(Cluster cluster, java.util.List<StoreDefinition> storeDefs)
           
 

Uses of StoreDefinition in voldemort.tools.admin
 

Methods in voldemort.tools.admin that return types with arguments of type StoreDefinition
static java.util.Map<java.lang.String,StoreDefinition> AdminToolUtils.getSystemStoreDefMap()
          Utility function that fetches system store definitions
static java.util.Map<java.lang.String,StoreDefinition> AdminToolUtils.getUserStoreDefMapOnNode(AdminClient adminClient, java.lang.Integer nodeId)
          Utility function that fetches user defined store definitions
 

Uses of StoreDefinition in voldemort.tools.admin.command
 

Method parameters in voldemort.tools.admin.command with type arguments of type StoreDefinition
static void AdminCommandMeta.SubCommandMetaSet.doMetaUpdateVersionsOnStores(AdminClient adminClient, java.util.List<StoreDefinition> oldStoreDefs, java.util.List<StoreDefinition> newStoreDefs)
          Updates metadata versions on stores.
static void AdminCommandMeta.SubCommandMetaSet.doMetaUpdateVersionsOnStores(AdminClient adminClient, java.util.List<StoreDefinition> oldStoreDefs, java.util.List<StoreDefinition> newStoreDefs)
          Updates metadata versions on stores.
 

Uses of StoreDefinition in voldemort.utils
 

Methods in voldemort.utils that return StoreDefinition
static StoreDefinition StoreDefinitionUtils.getStoreDefinitionWithName(java.util.List<StoreDefinition> storeDefs, java.lang.String storeName)
          Given a store name and a list of store definitions, returns the appropriate store definition ( if it exists )
 

Methods in voldemort.utils that return types with arguments of type StoreDefinition
static java.util.List<StoreDefinition> RebalanceUtils.dropZone(java.util.List<StoreDefinition> currentStoreDefs, int dropZoneId)
          Similar to RebalanceUtils.vacateZone(Cluster, int), takes the current store definitions in the cluster and creates store definitions with the specified zone effectively dropped.
static java.util.List<StoreDefinition> StoreDefinitionUtils.filterStores(java.util.List<StoreDefinition> storeDefs, boolean isReadOnly)
          Given a list of store definitions, filters the list depending on the boolean
static java.util.HashMap<StoreDefinition,java.lang.Integer> StoreDefinitionUtils.getUniqueStoreDefinitionsWithCounts(java.util.List<StoreDefinition> storeDefs)
          Given a list of store definitions, find out and return a map of similar store definitions + count of them
static java.util.List<StoreDefinition> RebalanceUtils.validateRebalanceStore(java.util.List<StoreDefinition> storeDefList)
          Given a list of store definitions, makes sure that rebalance supports all of them.
 

Methods in voldemort.utils with parameters of type StoreDefinition
static StoreDefinitionBuilder StoreDefinitionUtils.getBuilderForStoreDef(StoreDefinition storeDef)
           
static void StoreDefinitionUtils.validateSchemaAsNeeded(StoreDefinition storeDefinition)
          Validate store schema -- backward compatibility if it is AVRO generic versioned -- sanity checks for avro in general
 

Method parameters in voldemort.utils with type arguments of type StoreDefinition
static java.lang.String PartitionBalanceUtils.analyzeInvalidMetadataRate(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster finalCluster, java.util.List<StoreDefinition> finalStoreDefs)
          Compares current cluster with final cluster.
static java.lang.String PartitionBalanceUtils.analyzeInvalidMetadataRate(Cluster currentCluster, java.util.List<StoreDefinition> currentStoreDefs, Cluster finalCluster, java.util.List<StoreDefinition> finalStoreDefs)
          Compares current cluster with final cluster.
static java.util.List<StoreDefinition> RebalanceUtils.dropZone(java.util.List<StoreDefinition> currentStoreDefs, int dropZoneId)
          Similar to RebalanceUtils.vacateZone(Cluster, int), takes the current store definitions in the cluster and creates store definitions with the specified zone effectively dropped.
static void RebalanceUtils.dumpStoreDefsToFile(java.lang.String outputDirName, java.lang.String fileName, java.util.List<StoreDefinition> storeDefs)
          Prints a stores xml to a file.
static java.util.List<StoreDefinition> StoreDefinitionUtils.filterStores(java.util.List<StoreDefinition> storeDefs, boolean isReadOnly)
          Given a list of store definitions, filters the list depending on the boolean
static java.util.List<RebalanceTaskInfo> RebalanceUtils.filterTaskPlanWithStores(java.util.List<RebalanceTaskInfo> existingPlanList, java.util.List<StoreDefinition> storeDefs)
          Given a list of partition plans and a set of stores, copies the store names to every individual plan and creates a new list
static StoreDefinition StoreDefinitionUtils.getStoreDefinitionWithName(java.util.List<StoreDefinition> storeDefs, java.lang.String storeName)
          Given a store name and a list of store definitions, returns the appropriate store definition ( if it exists )
static java.util.List<java.lang.String> StoreDefinitionUtils.getStoreNames(java.util.List<StoreDefinition> storeDefList)
          Given a list of store definitions return a list of store names
static java.util.Set<java.lang.String> StoreDefinitionUtils.getStoreNamesSet(java.util.List<StoreDefinition> storeDefList)
          Given a list of store definitions return a set of store names
static java.util.HashMap<StoreDefinition,java.lang.Integer> StoreDefinitionUtils.getUniqueStoreDefinitionsWithCounts(java.util.List<StoreDefinition> storeDefs)
          Given a list of store definitions, find out and return a map of similar store definitions + count of them
static void RebalanceUtils.validateClusterStores(Cluster cluster, java.util.List<StoreDefinition> storeDefs)
          Verify store definitions are congruent with cluster definition.
static java.util.List<StoreDefinition> RebalanceUtils.validateRebalanceStore(java.util.List<StoreDefinition> storeDefList)
          Given a list of store definitions, makes sure that rebalance supports all of them.
static void StoreDefinitionUtils.validateSchemasAsNeeded(java.util.Collection<StoreDefinition> storeDefinitions)
          Validate store schema for things like backwards compatibility, parseability
 

Uses of StoreDefinition in voldemort.xml
 

Methods in voldemort.xml that return StoreDefinition
 StoreDefinition StoreDefinitionsMapper.readStore(java.io.Reader input)
           
 

Methods in voldemort.xml that return types with arguments of type StoreDefinition
 java.util.List<StoreDefinition> StoreDefinitionsMapper.readStoreList(java.io.File f)
           
 java.util.List<StoreDefinition> StoreDefinitionsMapper.readStoreList(java.io.Reader input)
           
 java.util.List<StoreDefinition> StoreDefinitionsMapper.readStoreList(java.io.Reader input, boolean verifySchema)
           
 

Methods in voldemort.xml with parameters of type StoreDefinition
 java.lang.String StoreDefinitionsMapper.writeStore(StoreDefinition store)
           
 

Method parameters in voldemort.xml with type arguments of type StoreDefinition
 java.lang.String StoreDefinitionsMapper.writeStoreList(java.util.List<StoreDefinition> stores)
           
 



Jay Kreps, Roshan Sumbaly, Alex Feinberg, Bhupesh Bansal, Lei Gao, Chinmay Soman, Vinoth Chandar, Zhongjie Wu