Modifier and Type | Method and Description |
---|---|
Range<Token> |
RingCache.getRange(java.nio.ByteBuffer key) |
Modifier and Type | Method and Description |
---|---|
java.util.List<java.net.InetAddress> |
RingCache.getEndpoint(Range<Token> range)
ListMultimap promises to return a List for get(K)
|
Modifier and Type | Method and Description |
---|---|
static java.util.Set<Range<Token>> |
SystemKeyspace.getAvailableRanges(java.lang.String keyspace,
IPartitioner partitioner) |
static java.util.Map<java.net.InetAddress,java.util.Set<Range<Token>>> |
SystemKeyspace.getTransferredRanges(java.lang.String description,
java.lang.String keyspace,
IPartitioner partitioner) |
Modifier and Type | Method and Description |
---|---|
long |
ColumnFamilyStore.estimatedKeysForRange(Range<Token> range) |
static DataRange |
DataRange.forKeyRange(Range<PartitionPosition> keyRange)
Creates a
DataRange to query all rows over the provided key range. |
static DataRange |
DataRange.forTokenRange(Range<Token> tokenRange)
Creates a
DataRange to query all rows over the provided token range. |
java.lang.Iterable<DecoratedKey> |
ColumnFamilyStore.keySamples(Range<Token> range) |
Modifier and Type | Method and Description |
---|---|
void |
ColumnFamilyStore.forceCompactionForTokenRange(java.util.Collection<Range<Token>> tokenRanges) |
void |
ColumnFamilyStoreMBean.forceCompactionForTokenRange(java.util.Collection<Range<Token>> tokenRanges)
force a major compaction of specified key range in this column family
|
static void |
SystemKeyspace.updateAvailableRanges(java.lang.String keyspace,
java.util.Collection<Range<Token>> completedRanges) |
static void |
SystemKeyspace.updateSizeEstimates(java.lang.String keyspace,
java.lang.String table,
java.util.Map<Range<Token>,Pair<java.lang.Long,java.lang.Long>> estimates)
Writes the current partition count and size estimates into SIZE_ESTIMATES_CF
|
static void |
SystemKeyspace.updateTransferredRanges(java.lang.String description,
java.net.InetAddress peer,
java.lang.String keyspace,
java.util.Collection<Range<Token>> streamedRanges) |
Modifier and Type | Method and Description |
---|---|
AbstractCompactionStrategy.ScannerList |
AbstractCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables,
Range<Token> range) |
Modifier and Type | Method and Description |
---|---|
void |
CompactionManager.forceCompactionForTokenRange(ColumnFamilyStore cfStore,
java.util.Collection<Range<Token>> ranges) |
AbstractCompactionStrategy.ScannerList |
AbstractCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables,
java.util.Collection<Range<Token>> ranges)
Returns a list of KeyScanners given sstables and a range on which to scan.
|
AbstractCompactionStrategy.ScannerList |
CompactionStrategyManager.getScanners(java.util.Collection<SSTableReader> sstables,
java.util.Collection<Range<Token>> ranges)
Create ISSTableScanners from the given sstables
Delegates the call to the compaction strategies to allow LCS to create a scanner
|
AbstractCompactionStrategy.ScannerList |
LeveledCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables,
java.util.Collection<Range<Token>> ranges) |
static boolean |
CompactionManager.needsCleanup(SSTableReader sstable,
java.util.Collection<Range<Token>> ownedRanges)
Determines if a cleanup would actually remove any data in this SSTable based
on a set of owned ranges.
|
void |
CompactionManager.performAnticompaction(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
Refs<SSTableReader> validatedForRepair,
LifecycleTransaction txn,
long repairedAt,
java.util.UUID parentRepairSession)
Make sure the {validatedForRepair} are marked for compaction before calling this.
|
com.google.common.util.concurrent.ListenableFuture<?> |
CompactionManager.submitAntiCompaction(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
Refs<SSTableReader> sstables,
long repairedAt,
java.util.UUID parentRepairSession)
Submit anti-compactions for a collection of SSTables over a set of repaired ranges and marks corresponding SSTables
as repaired.
|
Modifier and Type | Method and Description |
---|---|
static Range<PartitionPosition> |
Range.makeRowRange(Range<Token> tokenBounds) |
static Range<PartitionPosition> |
Range.makeRowRange(Token left,
Token right)
Compute a range of keys corresponding to a given range of token.
|
Modifier and Type | Method and Description |
---|---|
java.util.Set<Range<T>> |
Range.differenceToFetch(Range<T> rhs)
Calculate set of the difference ranges of given two ranges
(as current (A, B] and rhs is (C, D])
which node will need to fetch when moving to a given new token
|
java.util.Set<Range<Token>> |
StreamStateStore.getAvailableRanges(java.lang.String keyspace,
IPartitioner partitioner) |
static com.google.common.collect.Multimap<java.net.InetAddress,Range<Token>> |
RangeStreamer.getWorkMap(com.google.common.collect.Multimap<Range<Token>,java.net.InetAddress> rangesWithSourceTarget,
java.lang.String keyspace,
IFailureDetector fd,
boolean useStrictConsistency) |
java.util.Set<Range<T>> |
Range.intersectionWith(Range<T> that) |
static <T extends RingPosition<T>> |
Range.normalize(java.util.Collection<Range<T>> ranges) |
static <T extends RingPosition<T>> |
Range.rangeSet(Range<T>... ranges) |
static <T extends RingPosition<T>> |
Range.rangeSet(Range<T> range) |
static <T extends RingPosition<T>> |
Range.sort(java.util.Collection<Range<T>> ranges) |
java.util.Set<Range<T>> |
Range.subtract(Range<T> rhs) |
java.util.Set<Range<T>> |
Range.subtractAll(java.util.Collection<Range<T>> ranges) |
java.util.List<Range<T>> |
Range.unwrap() |
Modifier and Type | Method and Description |
---|---|
int |
Range.compareTo(Range<T> rhs)
Note: this class has a natural ordering that is inconsistent with equals
|
boolean |
Range.contains(Range<T> that) |
java.util.Set<Range<T>> |
Range.differenceToFetch(Range<T> rhs)
Calculate set of the difference ranges of given two ranges
(as current (A, B] and rhs is (C, D])
which node will need to fetch when moving to a given new token
|
java.util.Set<Range<T>> |
Range.intersectionWith(Range<T> that) |
boolean |
Range.intersects(Range<T> that) |
static Range<PartitionPosition> |
Range.makeRowRange(Range<Token> tokenBounds) |
static <T extends RingPosition<T>> |
Range.rangeSet(Range<T>... ranges) |
static <T extends RingPosition<T>> |
Range.rangeSet(Range<T> range) |
java.util.Set<Range<T>> |
Range.subtract(Range<T> rhs) |
Modifier and Type | Method and Description |
---|---|
void |
RangeStreamer.addRanges(java.lang.String keyspaceName,
java.util.Collection<Range<Token>> ranges)
Add ranges to be streamed for given keyspace.
|
static com.google.common.collect.Multimap<java.net.InetAddress,Range<Token>> |
RangeStreamer.getWorkMap(com.google.common.collect.Multimap<Range<Token>,java.net.InetAddress> rangesWithSourceTarget,
java.lang.String keyspace,
IFailureDetector fd,
boolean useStrictConsistency) |
boolean |
AbstractBounds.intersects(java.lang.Iterable<Range<T>> ranges)
return true if @param range intersects any of the given @param ranges
|
static <T extends RingPosition<T>> |
Range.isInRanges(T token,
java.lang.Iterable<Range<T>> ranges) |
static <T extends RingPosition<T>> |
Range.normalize(java.util.Collection<Range<T>> ranges) |
static <T extends RingPosition<T>> |
Range.sort(java.util.Collection<Range<T>> ranges) |
java.util.List<Token> |
Splitter.splitOwnedRanges(int parts,
java.util.List<Range<Token>> localRanges,
boolean dontSplitRanges) |
java.util.Set<Range<T>> |
Range.subtractAll(java.util.Collection<Range<T>> ranges) |
Constructor and Description |
---|
OrderedRangeContainmentChecker(java.util.Collection<Range<Token>> ranges) |
Modifier and Type | Method and Description |
---|---|
java.util.Map<java.net.InetAddress,java.util.Collection<Range<Token>>> |
SSTableLoader.Client.getEndpointToRangesMap() |
Modifier and Type | Method and Description |
---|---|
protected void |
SSTableLoader.Client.addRangeForEndpoint(Range<Token> range,
java.net.InetAddress endpoint) |
Modifier and Type | Method and Description |
---|---|
protected java.util.Collection<SSTableReader> |
SSTableLoader.openSSTables(java.util.Map<java.net.InetAddress,java.util.Collection<Range<Token>>> ranges) |
Modifier and Type | Method and Description |
---|---|
java.lang.Iterable<DecoratedKey> |
SSTableReader.getKeySamples(Range<Token> range) |
ISSTableScanner |
SSTableReader.getScanner(Range<Token> range,
com.google.common.util.concurrent.RateLimiter limiter)
Direct I/O SSTableScanner over a defined range of tokens.
|
Modifier and Type | Method and Description |
---|---|
long |
SSTableReader.estimatedKeysForRanges(java.util.Collection<Range<Token>> ranges) |
java.util.List<Pair<java.lang.Long,java.lang.Long>> |
SSTableReader.getPositionsForRanges(java.util.Collection<Range<Token>> ranges)
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
|
abstract ISSTableScanner |
SSTableReader.getScanner(java.util.Collection<Range<Token>> ranges,
com.google.common.util.concurrent.RateLimiter limiter)
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
|
Modifier and Type | Method and Description |
---|---|
ISSTableScanner |
BigTableReader.getScanner(java.util.Collection<Range<Token>> ranges,
com.google.common.util.concurrent.RateLimiter limiter)
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
|
static ISSTableScanner |
BigTableScanner.getScanner(SSTableReader sstable,
java.util.Collection<Range<Token>> tokenRanges,
com.google.common.util.concurrent.RateLimiter limiter) |
Modifier and Type | Method and Description |
---|---|
Range<Token> |
TokenMetadata.getPrimaryRangeFor(Token right)
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
com.google.common.collect.Multimap<java.net.InetAddress,Range<Token>> |
AbstractReplicationStrategy.getAddressRanges() |
com.google.common.collect.Multimap<java.net.InetAddress,Range<Token>> |
AbstractReplicationStrategy.getAddressRanges(TokenMetadata metadata) |
java.util.Collection<Range<Token>> |
AbstractReplicationStrategy.getPendingAddressRanges(TokenMetadata metadata,
java.util.Collection<Token> pendingTokens,
java.net.InetAddress pendingAddress) |
java.util.Collection<Range<Token>> |
AbstractReplicationStrategy.getPendingAddressRanges(TokenMetadata metadata,
Token pendingToken,
java.net.InetAddress pendingAddress) |
java.util.List<Range<Token>> |
TokenMetadata.getPendingRanges(java.lang.String keyspaceName,
java.net.InetAddress endpoint) |
com.google.common.collect.Multimap<Range<Token>,java.net.InetAddress> |
TokenMetadata.getPendingRangesMM(java.lang.String keyspaceName) |
java.util.Collection<Range<Token>> |
TokenMetadata.getPrimaryRangesFor(java.util.Collection<Token> tokens) |
com.google.common.collect.Multimap<Range<Token>,java.net.InetAddress> |
AbstractReplicationStrategy.getRangeAddresses(TokenMetadata metadata) |
java.util.Iterator<java.util.Map.Entry<Range<Token>,java.util.List<java.net.InetAddress>>> |
PendingRangeMaps.iterator() |
Modifier and Type | Method and Description |
---|---|
void |
PendingRangeMaps.addPendingRange(Range<Token> range,
java.net.InetAddress address) |
Modifier and Type | Field and Description |
---|---|
java.util.Collection<Range<Token>> |
RepairJobDesc.ranges
repairing range
|
java.util.Collection<Range<Token>> |
RepairSession.ranges
Range to repair
|
java.util.Collection<Range<Token>> |
RepairSessionResult.ranges |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<Range<Token>> |
RepairSession.getRanges() |
Modifier and Type | Method and Description |
---|---|
static void |
SystemDistributedKeyspace.startRepairs(java.util.UUID id,
java.util.UUID parent_id,
java.lang.String keyspaceName,
java.lang.String[] cfnames,
java.util.Collection<Range<Token>> ranges,
java.lang.Iterable<java.net.InetAddress> endpoints) |
protected void |
LocalSyncTask.startSync(java.util.List<Range<Token>> differences)
Starts sending/receiving our list of differences to/from the remote endpoint: creates a callback
that will be called out of band once the streams complete.
|
protected void |
RemoteSyncTask.startSync(java.util.List<Range<Token>> differences) |
protected abstract void |
SyncTask.startSync(java.util.List<Range<Token>> differences) |
static void |
SystemDistributedKeyspace.successfulParentRepair(java.util.UUID parent_id,
java.util.Collection<Range<Token>> successfulRanges) |
Constructor and Description |
---|
AnticompactionTask(java.util.UUID parentSession,
java.net.InetAddress neighbor,
java.util.Collection<Range<Token>> successfulRanges) |
RepairJobDesc(java.util.UUID parentSessionId,
java.util.UUID sessionId,
java.lang.String keyspace,
java.lang.String columnFamily,
java.util.Collection<Range<Token>> ranges) |
RepairSession(java.util.UUID parentRepairSession,
java.util.UUID id,
java.util.Collection<Range<Token>> ranges,
java.lang.String keyspace,
RepairParallelism parallelismDegree,
java.util.Set<java.net.InetAddress> endpoints,
long repairedAt,
boolean pullRepair,
java.lang.String... cfnames)
Create new repair session.
|
RepairSessionResult(java.util.UUID sessionId,
java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.util.Collection<RepairResult> repairJobResults) |
Modifier and Type | Field and Description |
---|---|
java.util.Collection<Range<Token>> |
PrepareMessage.ranges |
java.util.Collection<Range<Token>> |
SyncRequest.ranges |
java.util.Collection<Range<Token>> |
AnticompactionRequest.successfulRanges
Successfully repaired ranges.
|
Modifier and Type | Method and Description |
---|---|
java.util.Collection<Range<Token>> |
RepairOption.getRanges() |
Constructor and Description |
---|
AnticompactionRequest(java.util.UUID parentRepairSession,
java.util.Collection<Range<Token>> ranges) |
PrepareMessage(java.util.UUID parentRepairSession,
java.util.List<java.util.UUID> cfIds,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long timestamp,
boolean isGlobal) |
RepairOption(RepairParallelism parallelism,
boolean primaryRange,
boolean incremental,
boolean trace,
int jobThreads,
java.util.Collection<Range<Token>> ranges,
boolean isSubrangeRepair,
boolean pullRepair) |
SyncRequest(RepairJobDesc desc,
java.net.InetAddress initiator,
java.net.InetAddress src,
java.net.InetAddress dst,
java.util.Collection<Range<Token>> ranges) |
Modifier and Type | Method and Description |
---|---|
Pair<java.util.Set<Range<Token>>,java.util.Set<Range<Token>>> |
StorageService.calculateStreamAndFetchRanges(java.util.Collection<Range<Token>> current,
java.util.Collection<Range<Token>> updated)
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
|
Pair<java.util.Set<Range<Token>>,java.util.Set<Range<Token>>> |
StorageService.calculateStreamAndFetchRanges(java.util.Collection<Range<Token>> current,
java.util.Collection<Range<Token>> updated)
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
|
java.util.List<Range<Token>> |
StorageService.getAllRanges(java.util.List<Token> sortedTokens)
Get all ranges that span the ring given a set
of tokens.
|
java.util.Collection<Range<Token>> |
StorageService.getLocalRanges(java.lang.String keyspaceName) |
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRangeForEndpointWithinDC(java.lang.String keyspace,
java.net.InetAddress referenceEndpoint)
Get the "primary ranges" within local DC for the specified keyspace and endpoint.
|
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRanges(java.lang.String keyspace) |
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRangesForEndpoint(java.lang.String keyspace,
java.net.InetAddress ep)
Get the "primary ranges" for the specified keyspace and endpoint.
|
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRangesWithinDC(java.lang.String keyspace) |
java.util.Map<Range<Token>,java.util.List<java.net.InetAddress>> |
StorageService.getRangeToAddressMap(java.lang.String keyspace) |
java.util.Map<Range<Token>,java.util.List<java.net.InetAddress>> |
StorageService.getRangeToAddressMapInLocalDC(java.lang.String keyspace) |
java.util.List<Pair<Range<Token>,java.lang.Long>> |
StorageService.getSplits(java.lang.String keyspaceName,
java.lang.String cfName,
Range<Token> range,
int keysPerSplit) |
Modifier and Type | Method and Description |
---|---|
static java.util.Set<java.net.InetAddress> |
ActiveRepairService.getNeighbors(java.lang.String keyspaceName,
java.util.Collection<Range<Token>> keyspaceLocalRanges,
Range<Token> toRepair,
java.util.Collection<java.lang.String> dataCenters,
java.util.Collection<java.lang.String> hosts)
Return all of the neighbors with whom we share the provided range.
|
java.util.List<Pair<Range<Token>,java.lang.Long>> |
StorageService.getSplits(java.lang.String keyspaceName,
java.lang.String cfName,
Range<Token> range,
int keysPerSplit) |
Modifier and Type | Method and Description |
---|---|
Pair<java.util.Set<Range<Token>>,java.util.Set<Range<Token>>> |
StorageService.calculateStreamAndFetchRanges(java.util.Collection<Range<Token>> current,
java.util.Collection<Range<Token>> updated)
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
|
Pair<java.util.Set<Range<Token>>,java.util.Set<Range<Token>>> |
StorageService.calculateStreamAndFetchRanges(java.util.Collection<Range<Token>> current,
java.util.Collection<Range<Token>> updated)
Calculate pair of ranges to stream/fetch for given two range collections
(current ranges for keyspace and ranges after move to new token)
|
com.google.common.util.concurrent.ListenableFuture<java.util.List<java.lang.Object>> |
ActiveRepairService.doAntiCompaction(java.util.UUID parentRepairSession,
java.util.Collection<Range<Token>> successfulRanges)
Submit anti-compaction jobs to CompactionManager.
|
com.google.common.util.concurrent.ListenableFuture |
ActiveRepairService.finishParentSession(java.util.UUID parentSession,
java.util.Set<java.net.InetAddress> neighbors,
java.util.Collection<Range<Token>> successfulRanges)
Run final process of repair.
|
static java.util.Set<java.net.InetAddress> |
ActiveRepairService.getNeighbors(java.lang.String keyspaceName,
java.util.Collection<Range<Token>> keyspaceLocalRanges,
Range<Token> toRepair,
java.util.Collection<java.lang.String> dataCenters,
java.util.Collection<java.lang.String> hosts)
Return all of the neighbors with whom we share the provided range.
|
void |
ActiveRepairService.registerParentRepairSession(java.util.UUID parentRepairSession,
java.net.InetAddress coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long timestamp,
boolean isGlobal) |
RepairSession |
ActiveRepairService.submitRepairSession(java.util.UUID parentRepairSession,
java.util.Collection<Range<Token>> range,
java.lang.String keyspace,
RepairParallelism parallelismDegree,
java.util.Set<java.net.InetAddress> endpoints,
long repairedAt,
boolean pullRepair,
com.google.common.util.concurrent.ListeningExecutorService executor,
java.lang.String... cfnames)
Requests repairs for the given keyspace and column families.
|
Constructor and Description |
---|
ParentRepairSession(java.net.InetAddress coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long repairedAt,
boolean isGlobal) |
Modifier and Type | Field and Description |
---|---|
java.util.Collection<Range<Token>> |
StreamRequest.ranges |
java.util.Map<java.lang.String,java.util.Set<Range<Token>>> |
StreamEvent.SessionCompleteEvent.transferredRangesPerKeyspace |
java.util.Map<java.lang.String,java.util.Set<Range<Token>>> |
StreamSession.transferredRangesPerKeyspace |
Modifier and Type | Method and Description |
---|---|
void |
StreamSession.addStreamRequest(java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.util.Collection<java.lang.String> columnFamilies,
long repairedAt)
Request data fetch task to this session.
|
void |
StreamSession.addTransferRanges(java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.util.Collection<java.lang.String> columnFamilies,
boolean flushTables,
long repairedAt)
Set up transfer for specific keyspace/ranges/CFs
Used in repair - a streamed sstable in repair will be marked with the given repairedAt time
|
static java.util.List<StreamSession.SSTableStreamingSections> |
StreamSession.getSSTableSectionsForRanges(java.util.Collection<Range<Token>> ranges,
java.util.Collection<ColumnFamilyStore> stores,
long overriddenRepairedAt,
boolean isIncremental) |
StreamPlan |
StreamPlan.requestRanges(java.net.InetAddress from,
java.net.InetAddress connecting,
java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges)
Request data in
keyspace and ranges from specific node. |
StreamPlan |
StreamPlan.requestRanges(java.net.InetAddress from,
java.net.InetAddress connecting,
java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.lang.String... columnFamilies)
Request data in
columnFamilies under keyspace and ranges from specific node. |
StreamPlan |
StreamPlan.transferRanges(java.net.InetAddress to,
java.net.InetAddress connecting,
java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges)
Add transfer task to send data of specific keyspace and ranges.
|
StreamPlan |
StreamPlan.transferRanges(java.net.InetAddress to,
java.net.InetAddress connecting,
java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.lang.String... columnFamilies)
Add transfer task to send data of specific
columnFamilies under keyspace and ranges . |
StreamPlan |
StreamPlan.transferRanges(java.net.InetAddress to,
java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.lang.String... columnFamilies)
Add transfer task to send data of specific
columnFamilies under keyspace and ranges . |
Constructor and Description |
---|
StreamRequest(java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.util.Collection<java.lang.String> columnFamilies,
long repairedAt) |
Modifier and Type | Class and Description |
---|---|
static class |
MerkleTree.TreeDifference |
static class |
MerkleTree.TreeRange
The public interface to a range in the tree.
|
Modifier and Type | Field and Description |
---|---|
Range<Token> |
MerkleTree.fullRange
The top level range that this MerkleTree covers.
|
Modifier and Type | Method and Description |
---|---|
static java.util.List<Range<Token>> |
MerkleTrees.difference(MerkleTrees ltree,
MerkleTrees rtree)
Get the differences between the two sets of MerkleTrees.
|
java.util.Iterator<java.util.Map.Entry<Range<Token>,MerkleTree>> |
MerkleTrees.iterator()
Get an iterator of all ranges and their MerkleTrees.
|
java.util.Collection<Range<Token>> |
MerkleTrees.ranges()
Get the ranges that these merkle trees covers.
|
Modifier and Type | Method and Description |
---|---|
MerkleTree |
MerkleTrees.addMerkleTree(int maxsize,
byte hashdepth,
Range<Token> range) |
MerkleTree |
MerkleTrees.addMerkleTree(int maxsize,
Range<Token> range)
Add a MerkleTree with the defined size and range.
|
MerkleTree |
MerkleTrees.getMerkleTree(Range<Token> range)
Get the MerkleTree responsible for the given token range.
|
byte[] |
MerkleTree.hash(Range<Token> range)
Hash the given range in the tree.
|
byte[] |
MerkleTrees.hash(Range<Token> range) |
void |
MerkleTrees.init(Range<Token> range)
Init a selected MerkleTree with an even tree distribution.
|
void |
MerkleTrees.maxsize(Range<Token> range,
int maxsize) |
static void |
FBUtilities.sortSampledKeys(java.util.List<DecoratedKey> keys,
Range<Token> range) |
Modifier and Type | Method and Description |
---|---|
void |
MerkleTrees.addMerkleTrees(int maxsize,
java.util.Collection<Range<Token>> ranges)
Add merkle tree's with the defined maxsize and ranges.
|
Constructor and Description |
---|
MerkleTree(IPartitioner partitioner,
Range<Token> range,
byte hashdepth,
long maxsize) |
Copyright © 2020 The Apache Software Foundation