Modifier and Type | Field and Description |
---|---|
java.util.Set<Range<Token>> |
SystemKeyspace.AvailableRanges.full |
java.util.Set<Range<Token>> |
SystemKeyspace.AvailableRanges.trans |
Modifier and Type | Method and Description |
---|---|
static java.util.Map<InetAddressAndPort,java.util.Set<Range<Token>>> |
SystemKeyspace.getTransferredRanges(java.lang.String description,
java.lang.String keyspace,
IPartitioner partitioner) |
static java.util.Map<Range<Token>,Pair<Token,java.lang.Long>> |
SystemKeyspace.getViewBuildStatus(java.lang.String ksname,
java.lang.String viewName) |
static java.util.Set<Range<Token>> |
SystemKeyspace.rawRangesToRangeSet(java.util.Set<java.nio.ByteBuffer> rawRanges,
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) |
static void |
SystemKeyspace.updateViewBuildStatus(java.lang.String ksname,
java.lang.String viewName,
Range<Token> range,
Token lastToken,
long keysBuilt) |
Modifier and Type | Method and Description |
---|---|
void |
ColumnFamilyStore.forceCompactionForTokenRange(java.util.Collection<Range<Token>> tokenRanges) |
void |
ColumnFamilyStoreMBean.forceCompactionForTokenRange(java.util.Collection<Range<Token>> tokenRanges)
Forces a major compaction of specified token ranges in this column family.
|
static void |
SystemKeyspace.updateAvailableRanges(java.lang.String keyspace,
java.util.Collection<Range<Token>> completedFullRanges,
java.util.Collection<Range<Token>> completedTransientRanges) |
static void |
SystemKeyspace.updateAvailableRanges(java.lang.String keyspace,
java.util.Collection<Range<Token>> completedFullRanges,
java.util.Collection<Range<Token>> completedTransientRanges) |
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.updateTableEstimates(java.lang.String keyspace,
java.lang.String table,
java.lang.String type,
java.util.Map<Range<Token>,Pair<java.lang.Long,java.lang.Long>> estimates)
Writes the current partition count and size estimates into table_estimates
|
static void |
SystemKeyspace.updateTransferredRanges(StreamOperation streamOperation,
InetAddressAndPort peer,
java.lang.String keyspace,
java.util.Collection<Range<Token>> streamedRanges) |
Modifier and Type | Field and Description |
---|---|
java.util.function.Function<java.lang.String,? extends java.util.Collection<Range<Token>>> |
Verifier.Options.tokenLookup |
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)
Forces a major compaction of specified token ranges of the specified column family.
|
abstract java.util.List<ISSTableScanner> |
AbstractStrategyHolder.getScanners(AbstractStrategyHolder.GroupedSSTableContainer sstables,
java.util.Collection<Range<Token>> ranges) |
java.util.List<ISSTableScanner> |
CompactionStrategyHolder.getScanners(AbstractStrategyHolder.GroupedSSTableContainer sstables,
java.util.Collection<Range<Token>> ranges) |
java.util.List<ISSTableScanner> |
PendingRepairHolder.getScanners(AbstractStrategyHolder.GroupedSSTableContainer sstables,
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) |
AbstractCompactionStrategy.ScannerList |
LeveledCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables,
java.util.Collection<Range<Token>> ranges) |
AbstractCompactionStrategy.ScannerList |
CompactionStrategyManager.maybeGetScanners(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
|
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.
|
Verifier.Options.Builder |
Verifier.Options.Builder.tokenLookup(java.util.function.Function<java.lang.String,? extends java.util.Collection<Range<Token>>> tokenLookup) |
Constructor and Description |
---|
RangeOwnHelper(java.util.List<Range<Token>> normalizedRanges) |
Modifier and Type | Method and Description |
---|---|
java.util.Map<Range<Token>,java.lang.Long> |
CassandraValidationIterator.getRangePartitionCounts() |
Modifier and Type | Method and Description |
---|---|
protected PendingAntiCompaction.AcquisitionCallable |
PendingAntiCompaction.getAcquisitionCallable(ColumnFamilyStore cfs,
java.util.Set<Range<Token>> ranges,
java.util.UUID prsId,
int acquireRetrySeconds,
int acquireSleepMillis) |
ValidationPartitionIterator |
CassandraTableRepairManager.getValidationIterator(java.util.Collection<Range<Token>> ranges,
java.util.UUID parentId,
java.util.UUID sessionID,
boolean isIncremental,
int nowInSec) |
void |
CassandraTableRepairManager.snapshot(java.lang.String name,
java.util.Collection<Range<Token>> ranges,
boolean force) |
Constructor and Description |
---|
AcquisitionCallable(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
java.util.UUID sessionID,
int acquireRetrySeconds,
int acquireSleepMillis) |
CassandraValidationIterator(ColumnFamilyStore cfs,
java.util.Collection<Range<Token>> ranges,
java.util.UUID parentId,
java.util.UUID sessionID,
boolean isIncremental,
int nowInSec) |
Constructor and Description |
---|
CassandraOutgoingFile(StreamOperation operation,
Ref<SSTableReader> ref,
java.util.List<SSTableReader.PartitionPositionBounds> sections,
java.util.List<Range<Token>> normalizedRanges,
long estimatedKeys) |
Constructor and Description |
---|
ViewBuilderTask(ColumnFamilyStore baseCfs,
View view,
Range<Token> range,
Token lastToken,
long keysBuilt) |
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.
|
Range<Token> |
Splitter.WeightedRange.range() |
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
|
com.google.common.collect.Multimap<InetAddressAndPort,Range<Token>> |
RangeFetchMapCalculator.getRangeFetchMap() |
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<Token>> |
Splitter.split(java.util.Collection<Range<Token>> ranges,
int parts)
Splits the specified token ranges in at least
parts subranges. |
static <T extends RingPosition<T>> |
Range.subtract(java.util.Collection<Range<T>> ranges,
java.util.Collection<Range<T>> subtract) |
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
|
protected java.math.BigInteger |
Splitter.elapsedTokens(Token token,
Range<Token> range)
Computes the number of elapsed tokens from the range start until this 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) |
double |
Splitter.positionInRange(Token token,
Range<Token> range)
Computes the normalized position of this token relative to this range
|
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) |
protected java.math.BigInteger |
Splitter.tokensInRange(Range<Token> range) |
Modifier and Type | Method and Description |
---|---|
static <T extends RingPosition<T>> |
Range.assertNormalized(java.util.List<Range<T>> ranges) |
boolean |
AbstractBounds.intersects(java.lang.Iterable<Range<T>> ranges)
return true if @param range intersects any of the given @param ranges
|
static boolean |
Range.intersects(java.lang.Iterable<Range<Token>> l,
java.lang.Iterable<Range<Token>> r) |
static boolean |
Range.intersects(java.lang.Iterable<Range<Token>> l,
java.lang.Iterable<Range<Token>> r) |
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.Set<Range<Token>> |
Splitter.split(java.util.Collection<Range<Token>> ranges,
int parts)
Splits the specified token ranges in at least
parts subranges. |
static <T extends RingPosition<T>> |
Range.subtract(java.util.Collection<Range<T>> ranges,
java.util.Collection<Range<T>> subtract) |
static <T extends RingPosition<T>> |
Range.subtract(java.util.Collection<Range<T>> ranges,
java.util.Collection<Range<T>> subtract) |
java.util.Set<Range<T>> |
Range.subtractAll(java.util.Collection<Range<T>> ranges) |
Constructor and Description |
---|
WeightedRange(double weight,
Range<Token> range) |
Constructor and Description |
---|
OrderedRangeContainmentChecker(java.util.Collection<Range<Token>> ranges) |
Modifier and Type | Method and Description |
---|---|
java.util.Map<InetAddressAndPort,java.util.Collection<Range<Token>>> |
SSTableLoader.Client.getEndpointToRangesMap() |
Modifier and Type | Method and Description |
---|---|
protected void |
SSTableLoader.Client.addRangeForEndpoint(Range<Token> range,
InetAddressAndPort endpoint) |
Modifier and Type | Method and Description |
---|---|
protected java.util.Collection<SSTableReader> |
SSTableLoader.openSSTables(java.util.Map<InetAddressAndPort,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)
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<SSTableReader.PartitionPositionBounds> |
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)
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
|
boolean |
SSTableReader.intersects(java.util.Collection<Range<Token>> ranges) |
Modifier and Type | Method and Description |
---|---|
ISSTableScanner |
BigTableReader.getScanner(java.util.Collection<Range<Token>> ranges)
Direct I/O SSTableScanner over a defined collection of ranges of tokens.
|
static ISSTableScanner |
BigTableScanner.getScanner(SSTableReader sstable,
java.util.Collection<Range<Token>> tokenRanges) |
Modifier and Type | Field and Description |
---|---|
static Range<Token> |
SystemReplicas.FULL_RANGE |
Modifier and Type | Method and Description |
---|---|
Range<Token> |
TokenMetadata.getPrimaryRangeFor(Token right)
Deprecated.
|
Range<Token> |
EndpointsForRange.range() |
Range<Token> |
Replica.range() |
Modifier and Type | Method and Description |
---|---|
java.util.Map<Range<Token>,Replica> |
RangesAtEndpoint.byRange() |
java.util.Collection<Range<Token>> |
TokenMetadata.getPrimaryRangesFor(java.util.Collection<Token> tokens) |
java.util.Iterator<java.util.Map.Entry<Range<Token>,EndpointsForRange.Builder>> |
PendingRangeMaps.iterator() |
java.util.Set<Range<Token>> |
RangesAtEndpoint.ranges() |
Modifier and Type | Method and Description |
---|---|
void |
PendingRangeMaps.addPendingRange(Range<Token> range,
Replica replica) |
static EndpointsForRange.Builder |
EndpointsForRange.builder(Range<Token> range) |
static EndpointsForRange.Builder |
EndpointsForRange.builder(Range<Token> range,
int capacity) |
boolean |
Replica.contains(Range<Token> that) |
boolean |
RangesAtEndpoint.contains(Range<Token> range,
boolean isFull) |
Replica |
Replica.decorateSubrange(Range<Token> subrange) |
static EndpointsForRange |
EndpointsForRange.empty(Range<Token> range) |
static Replica |
Replica.fullReplica(InetAddressAndPort endpoint,
Range<Token> range) |
EndpointsForRange |
EndpointsByRange.get(Range<Token> range) |
protected EndpointsForRange.Builder |
EndpointsByRange.Builder.newBuilder(Range<Token> range) |
void |
EndpointsByRange.Builder.putAll(Range<Token> range,
EndpointsForRange replicas,
ReplicaCollection.Builder.Conflict ignoreConflicts) |
RangesAtEndpoint |
Replica.subtractIgnoreTransientStatus(Range<Token> subtract)
Don't use this method and ignore transient status unless you are explicitly handling it outside this method.
|
static Replica |
Replica.transientReplica(InetAddressAndPort endpoint,
Range<Token> range) |
Modifier and Type | Method and Description |
---|---|
static RangesAtEndpoint |
RangesAtEndpoint.toDummyList(java.util.Collection<Range<Token>> ranges)
Use of this method to synthesize Replicas is almost always wrong.
|
Constructor and Description |
---|
Builder(Range<Token> range) |
Builder(Range<Token> range,
int capacity) |
Replica(InetAddressAndPort endpoint,
Range<Token> range,
boolean full) |
Constructor and Description |
---|
EndpointsByRange(java.util.Map<Range<Token>,EndpointsForRange> map) |
Modifier and Type | Field and Description |
---|---|
java.util.Collection<Range<Token>> |
CommonRange.ranges |
java.util.Collection<Range<Token>> |
RepairJobDesc.ranges
repairing range
|
java.util.Collection<Range<Token>> |
RepairSessionResult.ranges |
java.util.List<Range<Token>> |
SyncTask.rangesToSync |
Modifier and Type | Method and Description |
---|---|
abstract java.util.Map<Range<Token>,java.lang.Long> |
ValidationPartitionIterator.getRangePartitionCounts() |
java.util.Collection<Range<Token>> |
RepairSession.ranges() |
Modifier and Type | Method and Description |
---|---|
ValidationPartitionIterator |
TableRepairManager.getValidationIterator(java.util.Collection<Range<Token>> ranges,
java.util.UUID parentId,
java.util.UUID sessionID,
boolean isIncremental,
int nowInSec)
Return a validation iterator for the given parameters.
|
void |
TableRepairManager.snapshot(java.lang.String name,
java.util.Collection<Range<Token>> ranges,
boolean force)
For snapshot repairs.
|
static void |
SystemDistributedKeyspace.successfulParentRepair(java.util.UUID parent_id,
java.util.Collection<Range<Token>> successfulRanges) |
Constructor and Description |
---|
AsymmetricRemoteSyncTask(RepairJobDesc desc,
InetAddressAndPort to,
InetAddressAndPort from,
java.util.List<Range<Token>> differences,
PreviewKind previewKind) |
CommonRange(java.util.Set<InetAddressAndPort> endpoints,
java.util.Set<InetAddressAndPort> transEndpoints,
java.util.Collection<Range<Token>> ranges) |
CommonRange(java.util.Set<InetAddressAndPort> endpoints,
java.util.Set<InetAddressAndPort> transEndpoints,
java.util.Collection<Range<Token>> ranges,
boolean hasSkippedReplicas) |
LocalSyncTask(RepairJobDesc desc,
InetAddressAndPort local,
InetAddressAndPort remote,
java.util.List<Range<Token>> diff,
java.util.UUID pendingRepair,
boolean requestRanges,
boolean transferRanges,
PreviewKind previewKind) |
RepairJobDesc(java.util.UUID parentSessionId,
java.util.UUID sessionId,
java.lang.String keyspace,
java.lang.String columnFamily,
java.util.Collection<Range<Token>> ranges) |
RepairSessionResult(java.util.UUID sessionId,
java.lang.String keyspace,
java.util.Collection<Range<Token>> ranges,
java.util.Collection<RepairResult> repairJobResults,
boolean skippedReplicas) |
StreamingRepairTask(RepairJobDesc desc,
InetAddressAndPort initiator,
InetAddressAndPort src,
InetAddressAndPort dst,
java.util.Collection<Range<Token>> ranges,
java.util.UUID pendingRepair,
PreviewKind previewKind,
boolean asymmetric) |
SymmetricRemoteSyncTask(RepairJobDesc desc,
InetAddressAndPort r1,
InetAddressAndPort r2,
java.util.List<Range<Token>> differences,
PreviewKind previewKind) |
SyncTask(RepairJobDesc desc,
InetAddressAndPort primaryEndpoint,
InetAddressAndPort peer,
java.util.List<Range<Token>> rangesToSync,
PreviewKind previewKind) |
Modifier and Type | Method and Description |
---|---|
static java.util.Set<Range<Token>> |
RangeDenormalizer.denormalize(Range<Token> range,
RangeMap<StreamFromOptions> incoming)
"Denormalizes" (kind of the opposite of what Range.normalize does) the ranges in the keys of {{incoming}}
It makes sure that if there is an intersection between {{range}} and some of the ranges in {{incoming.keySet()}}
we know that all intersections are keys in the updated {{incoming}}
|
java.util.Set<java.util.Map.Entry<Range<Token>,T>> |
RangeMap.entrySet() |
java.util.NavigableSet<Range<Token>> |
HostDifferences.get(InetAddressAndPort differingHost) |
com.google.common.collect.ImmutableMap<Range<Token>,StreamFromOptions> |
IncomingRepairStreamTracker.getIncoming() |
java.util.Set<Range<Token>> |
RangeMap.keySet() |
java.util.Set<java.util.Map.Entry<Range<Token>,T>> |
RangeMap.removeIntersecting(Range<Token> range) |
static java.util.Set<Range<Token>> |
RangeDenormalizer.subtractAll(java.util.Collection<java.util.Map.Entry<Range<Token>,StreamFromOptions>> ranges,
Range<Token> toSubtract)
copied from Range - need to iterate over the map entries
|
Modifier and Type | Method and Description |
---|---|
void |
IncomingRepairStreamTracker.addIncomingRangeFrom(Range<Token> range,
InetAddressAndPort streamFromNode)
Adds a range to be streamed from streamFromNode
First the currently tracked ranges are denormalized to make sure that no ranges overlap, then
the streamFromNode is added to the StreamFromOptions for the range
|
void |
HostDifferences.addSingleRange(InetAddressAndPort remoteNode,
Range<Token> rangeToFetch) |
StreamFromOptions |
StreamFromOptions.copy(Range<Token> withRange) |
static java.util.Set<Range<Token>> |
RangeDenormalizer.denormalize(Range<Token> range,
RangeMap<StreamFromOptions> incoming)
"Denormalizes" (kind of the opposite of what Range.normalize does) the ranges in the keys of {{incoming}}
It makes sure that if there is an intersection between {{range}} and some of the ranges in {{incoming.keySet()}}
we know that all intersections are keys in the updated {{incoming}}
|
boolean |
DifferenceHolder.hasDifferenceBetween(InetAddressAndPort node1,
InetAddressAndPort node2,
Range<Token> range) |
boolean |
HostDifferences.hasDifferencesFor(InetAddressAndPort node2,
Range<Token> range)
Does this instance have differences for range with node2?
|
T |
RangeMap.put(Range<Token> key,
T value) |
java.util.Set<java.util.Map.Entry<Range<Token>,T>> |
RangeMap.removeIntersecting(Range<Token> range) |
static java.util.Set<Range<Token>> |
RangeDenormalizer.subtractAll(java.util.Collection<java.util.Map.Entry<Range<Token>,StreamFromOptions>> ranges,
Range<Token> toSubtract)
copied from Range - need to iterate over the map entries
|
Modifier and Type | Method and Description |
---|---|
void |
HostDifferences.add(InetAddressAndPort endpoint,
java.util.Collection<Range<Token>> difference)
Adds a set of differences between the node this instance is tracking and endpoint
|
void |
RangeMap.putAll(java.util.Map<? extends Range<Token>,? extends T> m) |
static java.util.Set<Range<Token>> |
RangeDenormalizer.subtractAll(java.util.Collection<java.util.Map.Entry<Range<Token>,StreamFromOptions>> ranges,
Range<Token> toSubtract)
copied from Range - need to iterate over the map entries
|
Constructor and Description |
---|
StreamFromOptions(DifferenceHolder differences,
Range<Token> range) |
Modifier and Type | Field and Description |
---|---|
Range<Token> |
RepairedState.Section.range |
Modifier and Type | Field and Description |
---|---|
com.google.common.collect.ImmutableSet<Range<Token>> |
ConsistentSession.ranges |
Modifier and Type | Method and Description |
---|---|
void |
RepairedState.add(java.util.Collection<Range<Token>> ranges,
long repairedAt) |
CleanupSummary |
LocalSessions.cleanup(TableId tid,
java.util.Collection<Range<Token>> ranges,
boolean force) |
PendingStats |
LocalSessions.getPendingStats(TableId tid,
java.util.Collection<Range<Token>> ranges) |
RepairedState.Stats |
RepairedState.getRepairedStats(java.util.Collection<Range<Token>> ranges) |
RepairedState.Stats |
LocalSessions.getRepairedStats(TableId tid,
java.util.Collection<Range<Token>> ranges) |
boolean |
ConsistentSession.intersects(java.lang.Iterable<Range<Token>> otherRanges) |
long |
RepairedState.minRepairedAt(java.util.Collection<Range<Token>> ranges) |
java.util.List<java.util.Map<java.lang.String,java.lang.String>> |
LocalSessions.sessionInfo(boolean all,
java.util.Set<Range<Token>> ranges) |
Modifier and Type | Field and Description |
---|---|
java.util.Collection<Range<Token>> |
PrepareMessage.ranges |
java.util.Collection<Range<Token>> |
SyncRequest.ranges |
Modifier and Type | Method and Description |
---|---|
java.util.Collection<Range<Token>> |
RepairOption.getRanges() |
static java.util.Set<Range<Token>> |
RepairOption.parseRanges(java.lang.String rangesStr,
IPartitioner partitioner) |
Constructor and Description |
---|
PrepareMessage(java.util.UUID parentRepairSession,
java.util.List<TableId> tableIds,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long timestamp,
boolean isGlobal,
PreviewKind previewKind) |
RepairOption(RepairParallelism parallelism,
boolean primaryRange,
boolean incremental,
boolean trace,
int jobThreads,
java.util.Collection<Range<Token>> ranges,
boolean isSubrangeRepair,
boolean pullRepair,
boolean forceRepair,
PreviewKind previewKind,
boolean optimiseStreams,
boolean ignoreUnreplicatedKeyspaces) |
SyncRequest(RepairJobDesc desc,
InetAddressAndPort initiator,
InetAddressAndPort src,
InetAddressAndPort dst,
java.util.Collection<Range<Token>> ranges,
PreviewKind previewKind,
boolean asymmetric) |
Modifier and Type | Field and Description |
---|---|
Range<Token> |
TokenRange.range |
Modifier and Type | Method and Description |
---|---|
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.List<Range<Token>> |
StorageService.getLocalAndPendingRanges(java.lang.String ks) |
java.util.Collection<Range<Token>> |
StorageService.getLocalPrimaryRange() |
java.util.Collection<Range<Token>> |
StorageService.getLocalPrimaryRangeForEndpoint(InetAddressAndPort referenceEndpoint) |
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRangeForEndpointWithinDC(java.lang.String keyspace,
InetAddressAndPort 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,
InetAddressAndPort ep)
Get the "primary ranges" for the specified keyspace and endpoint.
|
java.util.Collection<Range<Token>> |
StorageService.getPrimaryRangesWithinDC(java.lang.String keyspace) |
java.util.Set<Range<Token>> |
ActiveRepairService.ParentRepairSession.getRanges() |
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 TokenRange |
TokenRange.create(Token.TokenFactory tokenFactory,
Range<Token> range,
java.util.List<InetAddressAndPort> endpoints,
boolean withPorts) |
static EndpointsForRange |
ActiveRepairService.getNeighbors(java.lang.String keyspaceName,
java.lang.Iterable<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 |
---|---|
static EndpointsForRange |
ActiveRepairService.getNeighbors(java.lang.String keyspaceName,
java.lang.Iterable<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,
InetAddressAndPort coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long repairedAt,
boolean isGlobal,
PreviewKind previewKind) |
Constructor and Description |
---|
ParentRepairSession(InetAddressAndPort coordinator,
java.util.List<ColumnFamilyStore> columnFamilyStores,
java.util.Collection<Range<Token>> ranges,
boolean isIncremental,
long repairedAt,
boolean isGlobal,
PreviewKind previewKind) |
Modifier and Type | Field and Description |
---|---|
java.util.Map<java.lang.String,java.util.Set<Range<Token>>> |
StreamEvent.SessionCompleteEvent.transferredRangesPerKeyspace |
Modifier and Type | Class and Description |
---|---|
static class |
MerkleTree.TreeRange
The public interface to a range in the tree.
|
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[] |
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,
int hashdepth,
long maxsize) |
Copyright © 2009-2022 The Apache Software Foundation