Uses of Class
org.apache.cassandra.dht.Token

Packages that use Token
org.apache.cassandra.client   
org.apache.cassandra.db   
org.apache.cassandra.db.compaction   
org.apache.cassandra.db.marshal   
org.apache.cassandra.dht   
org.apache.cassandra.gms   
org.apache.cassandra.io.sstable   
org.apache.cassandra.locator   
org.apache.cassandra.service   
org.apache.cassandra.streaming   
org.apache.cassandra.utils   
 

Uses of Token in org.apache.cassandra.client
 

Methods in org.apache.cassandra.client that return types with arguments of type Token
 Range<Token> RingCache.getRange(java.nio.ByteBuffer key)
           
 

Method parameters in org.apache.cassandra.client with type arguments of type Token
 java.util.List<java.net.InetAddress> RingCache.getEndpoint(Range<Token> range)
          ListMultimap promises to return a List for get(K)
 

Uses of Token in org.apache.cassandra.db
 

Fields in org.apache.cassandra.db declared as Token
 Token DecoratedKey.token
           
 

Methods in org.apache.cassandra.db that return Token
 Token DecoratedKey.getToken()
           
abstract  Token RowPosition.getToken()
           
 

Methods in org.apache.cassandra.db that return types with arguments of type Token
static java.util.Collection<Token> SystemTable.getSavedTokens()
           
static com.google.common.collect.SetMultimap<java.net.InetAddress,Token> SystemTable.loadTokens()
          Return a map of stored tokens to IP addresses
static java.util.Collection<Token> SystemTable.updateLocalTokens(java.util.Collection<Token> addTokens, java.util.Collection<Token> rmTokens)
          Convenience method to update the list of tokens in the local system table.
 

Method parameters in org.apache.cassandra.db with type arguments of type Token
 java.lang.Iterable<DecoratedKey> ColumnFamilyStore.keySamples(Range<Token> range)
           
static void SystemTable.removeTokens(java.util.Collection<Token> tokens)
          Remove stored tokens being used by another node
static java.util.Collection<Token> SystemTable.updateLocalTokens(java.util.Collection<Token> addTokens, java.util.Collection<Token> rmTokens)
          Convenience method to update the list of tokens in the local system table.
static java.util.Collection<Token> SystemTable.updateLocalTokens(java.util.Collection<Token> addTokens, java.util.Collection<Token> rmTokens)
          Convenience method to update the list of tokens in the local system table.
static void SystemTable.updateTokens(java.util.Collection<Token> tokens)
          This method is used to update the System Table with the new tokens for this node
static void SystemTable.updateTokens(java.net.InetAddress ep, java.util.Collection<Token> tokens)
          Record tokens being used by another node
 

Constructors in org.apache.cassandra.db with parameters of type Token
DecoratedKey(Token token, java.nio.ByteBuffer key)
           
 

Uses of Token in org.apache.cassandra.db.compaction
 

Method parameters in org.apache.cassandra.db.compaction with type arguments of type Token
 java.util.List<ICompactionScanner> AbstractCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables, Range<Token> range)
          Returns a list of KeyScanners given sstables and a range on which to scan.
 java.util.List<ICompactionScanner> LeveledCompactionStrategy.getScanners(java.util.Collection<SSTableReader> sstables, Range<Token> range)
           
 

Uses of Token in org.apache.cassandra.db.marshal
 

Classes in org.apache.cassandra.db.marshal with type parameters of type Token
 class LocalByPartionerType<T extends Token>
          for sorting columns representing row keys in the row ordering as determined by a partitioner.
 

Uses of Token in org.apache.cassandra.dht
 

Classes in org.apache.cassandra.dht with type parameters of type Token
 class AbstractPartitioner<T extends Token>
           
 interface IPartitioner<T extends Token>
           
 

Subclasses of Token in org.apache.cassandra.dht
 class BigIntegerToken
           
 class BytesToken
           
 class LocalToken
           
 class LongToken
           
 class StringToken
           
 

Fields in org.apache.cassandra.dht with type parameters of type Token
protected  java.util.Collection<Token> BootStrapper.tokens
           
 

Methods in org.apache.cassandra.dht that return Token
 Token Token.TokenSerializer.deserialize(java.io.DataInput dis)
           
abstract  Token<T> Token.TokenFactory.fromByteArray(java.nio.ByteBuffer bytes)
           
abstract  Token<T> Token.TokenFactory.fromString(java.lang.String string)
           
static Token BootStrapper.getBalancedToken(TokenMetadata metadata, java.util.Map<java.net.InetAddress,java.lang.Double> load)
          Deprecated. 
 Token RingPosition.getToken()
           
 Token<T> Token.getToken()
           
 Token Token.KeyBound.getToken()
           
 Token IPartitioner.midpoint(Token left, Token right)
          Calculate a Token representing the approximate "middle" of the given range.
 Token LocalPartitioner.midpoint(Token left, Token right)
           
 Token Murmur3Partitioner.midpoint(Token lToken, Token rToken)
           
 Token RandomPartitioner.midpoint(Token ltoken, Token rtoken)
           
 

Methods in org.apache.cassandra.dht that return types with arguments of type Token
 java.util.Map<Token,java.lang.Float> AbstractByteOrderedPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> IPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
          Calculate the deltas between tokens in the ring in order to compare relative sizes.
 java.util.Map<Token,java.lang.Float> LocalPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> Murmur3Partitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> OrderPreservingPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> RandomPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
static java.util.Collection<Token> BootStrapper.getBootstrapTokens(TokenMetadata metadata, java.util.Map<java.net.InetAddress,java.lang.Double> load)
          if initialtoken was specified, use that (split on comma).
static java.util.Collection<Token> BootStrapper.getRandomTokens(TokenMetadata metadata, int numTokens)
           
static com.google.common.collect.Multimap<java.net.InetAddress,Range<Token>> RangeStreamer.getWorkMap(com.google.common.collect.Multimap<Range<Token>,java.net.InetAddress> rangesWithSourceTarget)
           
abstract  AbstractBounds<Token> AbstractBounds.toTokenBounds()
          Transform this abstract bounds to a token abstract bounds.
 AbstractBounds<Token> Bounds.toTokenBounds()
           
 AbstractBounds<Token> ExcludingBounds.toTokenBounds()
           
 AbstractBounds<Token> IncludingExcludingBounds.toTokenBounds()
           
 AbstractBounds<Token> Range.toTokenBounds()
           
 

Methods in org.apache.cassandra.dht with parameters of type Token
 int BigIntegerToken.compareTo(Token<java.math.BigInteger> o)
           
 int BytesToken.compareTo(Token<byte[]> o)
           
 int LocalToken.compareTo(Token<java.nio.ByteBuffer> o)
           
 int LongToken.compareTo(Token<java.lang.Long> o)
           
 int StringToken.compareTo(Token<java.lang.String> o)
           
abstract  int Token.compareTo(Token<T> o)
          This determines the comparison for node destination purposes.
static Bounds<RowPosition> Bounds.makeRowBounds(Token left, Token right, IPartitioner partitioner)
          Compute a bounds of keys corresponding to a given bounds of token.
static Bounds<RowPosition> Bounds.makeRowBounds(Token left, Token right, IPartitioner partitioner)
          Compute a bounds of keys corresponding to a given bounds of token.
static Range<RowPosition> Range.makeRowRange(Token left, Token right, IPartitioner partitioner)
          Compute a range of keys corresponding to a given range of token.
static Range<RowPosition> Range.makeRowRange(Token left, Token right, IPartitioner partitioner)
          Compute a range of keys corresponding to a given range of token.
 BytesToken AbstractByteOrderedPartitioner.midpoint(Token ltoken, Token rtoken)
           
 BytesToken AbstractByteOrderedPartitioner.midpoint(Token ltoken, Token rtoken)
           
 Token IPartitioner.midpoint(Token left, Token right)
          Calculate a Token representing the approximate "middle" of the given range.
 Token IPartitioner.midpoint(Token left, Token right)
          Calculate a Token representing the approximate "middle" of the given range.
 Token LocalPartitioner.midpoint(Token left, Token right)
           
 Token LocalPartitioner.midpoint(Token left, Token right)
           
 Token Murmur3Partitioner.midpoint(Token lToken, Token rToken)
           
 Token Murmur3Partitioner.midpoint(Token lToken, Token rToken)
           
 StringToken OrderPreservingPartitioner.midpoint(Token ltoken, Token rtoken)
           
 StringToken OrderPreservingPartitioner.midpoint(Token ltoken, Token rtoken)
           
 Token RandomPartitioner.midpoint(Token ltoken, Token rtoken)
           
 Token RandomPartitioner.midpoint(Token ltoken, Token rtoken)
           
 void Token.TokenSerializer.serialize(Token token, java.io.DataOutput dos)
           
 long Token.TokenSerializer.serializedSize(Token object, TypeSizes typeSizes)
           
abstract  java.nio.ByteBuffer Token.TokenFactory.toByteArray(Token<T> token)
           
abstract  java.lang.String Token.TokenFactory.toString(Token<T> token)
           
 

Method parameters in org.apache.cassandra.dht with type arguments of type Token
 void RangeStreamer.addRanges(java.lang.String table, java.util.Collection<Range<Token>> ranges)
           
 java.util.Map<Token,java.lang.Float> AbstractByteOrderedPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> IPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
          Calculate the deltas between tokens in the ring in order to compare relative sizes.
 java.util.Map<Token,java.lang.Float> LocalPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> Murmur3Partitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> OrderPreservingPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
 java.util.Map<Token,java.lang.Float> RandomPartitioner.describeOwnership(java.util.List<Token> sortedTokens)
           
static com.google.common.collect.Multimap<java.net.InetAddress,Range<Token>> RangeStreamer.getWorkMap(com.google.common.collect.Multimap<Range<Token>,java.net.InetAddress> rangesWithSourceTarget)
           
 

Constructor parameters in org.apache.cassandra.dht with type arguments of type Token
BootStrapper(java.net.InetAddress address, java.util.Collection<Token> tokens, TokenMetadata tmd)
           
 

Uses of Token in org.apache.cassandra.gms
 

Methods in org.apache.cassandra.gms that return types with arguments of type Token
static java.util.Collection<Token> TokenSerializer.deserialize(IPartitioner partitioner, java.io.DataInput dis)
           
 

Methods in org.apache.cassandra.gms with parameters of type Token
 VersionedValue VersionedValue.VersionedValueFactory.moving(Token token)
           
 

Method parameters in org.apache.cassandra.gms with type arguments of type Token
 VersionedValue VersionedValue.VersionedValueFactory.bootstrapping(java.util.Collection<Token> tokens)
           
 VersionedValue VersionedValue.VersionedValueFactory.leaving(java.util.Collection<Token> tokens)
           
 VersionedValue VersionedValue.VersionedValueFactory.left(java.util.Collection<Token> tokens, long expireTime)
           
 VersionedValue VersionedValue.VersionedValueFactory.normal(java.util.Collection<Token> tokens)
           
 VersionedValue VersionedValue.VersionedValueFactory.relocating(java.util.Collection<Token> srcTokens)
           
static void TokenSerializer.serialize(IPartitioner partitioner, java.util.Collection<Token> tokens, java.io.DataOutput dos)
           
static long TokenSerializer.serializedSize(java.util.Collection<Token> tokens, TypeSizes typeSizes)
           
 VersionedValue VersionedValue.VersionedValueFactory.tokens(java.util.Collection<Token> tokens)
           
 

Uses of Token in org.apache.cassandra.io.sstable
 

Methods in org.apache.cassandra.io.sstable that return types with arguments of type Token
 java.util.Map<java.net.InetAddress,java.util.Collection<Range<Token>>> SSTableLoader.Client.getEndpointToRangesMap()
           
 

Method parameters in org.apache.cassandra.io.sstable with type arguments of type Token
protected  void SSTableLoader.Client.addRangeForEndpoint(Range<Token> range, java.net.InetAddress endpoint)
           
 long SSTableReader.estimatedKeysForRanges(java.util.Collection<Range<Token>> ranges)
           
 SSTableScanner SSTableReader.getDirectScanner(Range<Token> range)
          Direct I/O SSTableScanner over a defined range of tokens.
 java.lang.Iterable<DecoratedKey> SSTableReader.getKeySamples(Range<Token> range)
           
 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.
 

Uses of Token in org.apache.cassandra.locator
 

Methods in org.apache.cassandra.locator that return Token
static Token TokenMetadata.firstToken(java.util.ArrayList<Token> ring, Token start)
           
 Token TokenMetadata.getPredecessor(Token token)
           
 Token TokenMetadata.getSuccessor(Token token)
           
 Token TokenMetadata.getToken(java.net.InetAddress endpoint)
          Deprecated. 
 

Methods in org.apache.cassandra.locator that return types with arguments of type Token
 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)
           
 BiMultiValMap<Token,java.net.InetAddress> TokenMetadata.getBootstrapTokens()
           
 com.google.common.collect.Multimap<java.net.InetAddress,Token> TokenMetadata.getEndpointToTokenMapForReading()
           
 java.util.Set<Pair<Token,java.net.InetAddress>> TokenMetadata.getMovingEndpoints()
          Endpoints which are migrating to the new tokens
 java.util.Map<Token,java.net.InetAddress> TokenMetadata.getNormalAndBootstrappingTokenToEndpointMap()
           
 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.Map<Range<Token>,java.util.Collection<java.net.InetAddress>> TokenMetadata.getPendingRanges(java.lang.String table)
          a mutable map may be returned but caller should not modify it
 java.util.List<Range<Token>> TokenMetadata.getPendingRanges(java.lang.String table, java.net.InetAddress endpoint)
           
 Range<Token> TokenMetadata.getPrimaryRangeFor(Token right)
          Deprecated. 
 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.Map<Token,java.net.InetAddress> TokenMetadata.getRelocatingRanges()
          Ranges which are migrating to new endpoints.
 java.util.Collection<Token> TokenMetadata.getTokens(java.net.InetAddress endpoint)
           
static java.util.Iterator<Token> TokenMetadata.ringIterator(java.util.ArrayList<Token> ring, Token start, boolean includeMin)
          iterator over the Tokens in the given ring, starting with the token for the node owning start (which does not have to be a Token in the ring)
 java.util.ArrayList<Token> TokenMetadata.sortedTokens()
           
 

Methods in org.apache.cassandra.locator with parameters of type Token
 void TokenMetadata.addBootstrapToken(Token token, java.net.InetAddress endpoint)
          Deprecated. 
 void TokenMetadata.addMovingEndpoint(Token token, java.net.InetAddress endpoint)
          Add a new moving endpoint
 void AbstractReplicationStrategy.cacheEndpoint(Token t, java.util.ArrayList<java.net.InetAddress> addr)
           
abstract  java.util.List<java.net.InetAddress> AbstractReplicationStrategy.calculateNaturalEndpoints(Token searchToken, TokenMetadata tokenMetadata)
          calculate the natural endpoints for the given token
 java.util.List<java.net.InetAddress> LocalStrategy.calculateNaturalEndpoints(Token token, TokenMetadata metadata)
           
 java.util.List<java.net.InetAddress> NetworkTopologyStrategy.calculateNaturalEndpoints(Token searchToken, TokenMetadata tokenMetadata)
          calculate endpoints in one pass through the tokens by tracking our progress in each DC, rack etc.
 java.util.List<java.net.InetAddress> OldNetworkTopologyStrategy.calculateNaturalEndpoints(Token token, TokenMetadata metadata)
           
 java.util.List<java.net.InetAddress> SimpleStrategy.calculateNaturalEndpoints(Token token, TokenMetadata metadata)
           
static Token TokenMetadata.firstToken(java.util.ArrayList<Token> ring, Token start)
           
static int TokenMetadata.firstTokenIndex(java.util.ArrayList ring, Token start, boolean insertMin)
           
 java.util.ArrayList<java.net.InetAddress> AbstractReplicationStrategy.getCachedEndpoints(Token t)
           
 java.net.InetAddress TokenMetadata.getEndpoint(Token token)
           
 java.util.Collection<Range<Token>> AbstractReplicationStrategy.getPendingAddressRanges(TokenMetadata metadata, Token pendingToken, java.net.InetAddress pendingAddress)
           
 Token TokenMetadata.getPredecessor(Token token)
           
 Range<Token> TokenMetadata.getPrimaryRangeFor(Token right)
          Deprecated. 
 Token TokenMetadata.getSuccessor(Token token)
           
 java.util.Collection<java.net.InetAddress> TokenMetadata.getWriteEndpoints(Token token, java.lang.String table, java.util.Collection<java.net.InetAddress> naturalEndpoints)
          Deprecated. retained for benefit of old tests
 boolean TokenMetadata.isRelocating(Token token)
           
 java.util.Collection<java.net.InetAddress> TokenMetadata.pendingEndpointsFor(Token token, java.lang.String table)
           
 void TokenMetadata.removeFromRelocating(Token token, java.net.InetAddress endpoint)
          Remove pair of token/address from relocating ranges.
static java.util.Iterator<Token> TokenMetadata.ringIterator(java.util.ArrayList<Token> ring, Token start, boolean includeMin)
          iterator over the Tokens in the given ring, starting with the token for the node owning start (which does not have to be a Token in the ring)
 void TokenMetadata.updateNormalToken(Token token, java.net.InetAddress endpoint)
          Update token map with a single token/endpoint pair in normal state.
 

Method parameters in org.apache.cassandra.locator with type arguments of type Token
 void TokenMetadata.addBootstrapTokens(java.util.Collection<Token> tokens, java.net.InetAddress endpoint)
           
 void TokenMetadata.addRelocatingTokens(java.util.Collection<Token> tokens, java.net.InetAddress endpoint)
          Add new relocating ranges (tokens moving from their respective endpoints, to another).
static Token TokenMetadata.firstToken(java.util.ArrayList<Token> ring, Token start)
           
 java.util.Collection<Range<Token>> AbstractReplicationStrategy.getPendingAddressRanges(TokenMetadata metadata, java.util.Collection<Token> pendingTokens, java.net.InetAddress pendingAddress)
           
 java.util.Collection<Range<Token>> TokenMetadata.getPrimaryRangesFor(java.util.Collection<Token> tokens)
           
 void TokenMetadata.removeBootstrapTokens(java.util.Collection<Token> tokens)
           
static java.util.Iterator<Token> TokenMetadata.ringIterator(java.util.ArrayList<Token> ring, Token start, boolean includeMin)
          iterator over the Tokens in the given ring, starting with the token for the node owning start (which does not have to be a Token in the ring)
 void TokenMetadata.setPendingRanges(java.lang.String table, com.google.common.collect.Multimap<Range<Token>,java.net.InetAddress> rangeMap)
           
 void TokenMetadata.updateNormalTokens(java.util.Collection<Token> tokens, java.net.InetAddress endpoint)
           
 void TokenMetadata.updateNormalTokens(com.google.common.collect.Multimap<java.net.InetAddress,Token> endpointTokens)
          Update token map with a set of token/endpoint pairs in normal state.
 

Constructor parameters in org.apache.cassandra.locator with type arguments of type Token
TokenMetadata(BiMultiValMap<Token,java.net.InetAddress> tokenToEndpointMap, TokenMetadata.Topology topology)
           
 

Uses of Token in org.apache.cassandra.service
 

Fields in org.apache.cassandra.service with type parameters of type Token
 Range<Token> AntiEntropyService.TreeRequest.range
           
 

Methods in org.apache.cassandra.service that return Token
 Token StorageService.getBootstrapToken()
          return a token to which if a node bootstraps it will get about 1/2 of this node's range
 

Methods in org.apache.cassandra.service that return types with arguments of type 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 table 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 table 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.
 Range<Token> StorageService.getLocalPrimaryRange()
          Deprecated. 
 java.util.Collection<Range<Token>> StorageService.getLocalPrimaryRanges()
           
 java.util.Collection<Range<Token>> StorageService.getLocalRanges(java.lang.String table)
           
 java.util.Collection<Token> StorageService.getLocalTokens()
           
 Range<Token> StorageService.getPrimaryRangeForEndpoint(java.net.InetAddress ep)
          Deprecated. 
 java.util.Collection<Range<Token>> StorageService.getPrimaryRangesForEndpoint(java.net.InetAddress ep)
          Get the primary ranges for the specified endpoint.
 java.util.Map<Range<Token>,java.util.List<java.net.InetAddress>> StorageService.getRangeToAddressMap(java.lang.String keyspace)
           
 java.util.List<Pair<Range<Token>,java.lang.Long>> StorageService.getSplits(java.lang.String table, java.lang.String cfName, Range<Token> range, int keysPerSplit)
           
 

Methods in org.apache.cassandra.service with parameters of type Token
 java.net.InetAddress StorageService.getSuccessor(Token token)
           
 

Method parameters in org.apache.cassandra.service with type arguments of type 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 table 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 table and ranges after move to new token)
 AntiEntropyService.RepairFuture StorageService.forceTableRepair(Range<Token> range, java.lang.String tableName, boolean isSequential, boolean isLocal, java.lang.String... columnFamilies)
           
 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<Pair<Range<Token>,java.lang.Long>> StorageService.getSplits(java.lang.String table, java.lang.String cfName, Range<Token> range, int keysPerSplit)
           
 void StorageService.setTokens(java.util.Collection<Token> tokens)
          This method updates the local token on disk
 AntiEntropyService.RepairFuture AntiEntropyService.submitRepairSession(Range<Token> range, java.lang.String tablename, boolean isSequential, boolean isLocal, java.lang.String... cfnames)
          Requests repairs for the given table and column families, and blocks until all repairs have been completed.
 

Constructor parameters in org.apache.cassandra.service with type arguments of type Token
AntiEntropyService.TreeRequest(java.lang.String sessionid, java.net.InetAddress endpoint, Range<Token> range, AntiEntropyService.CFPair cf)
           
 

Uses of Token in org.apache.cassandra.streaming
 

Fields in org.apache.cassandra.streaming with type parameters of type Token
protected  java.util.Collection<Range<Token>> StreamRequest.ranges
           
 

Method parameters in org.apache.cassandra.streaming with type arguments of type Token
static StreamingRepairTask StreamingRepairTask.create(java.net.InetAddress ep1, java.net.InetAddress ep2, java.lang.String tableName, java.lang.String cfName, java.util.Collection<Range<Token>> ranges, java.lang.Runnable callback)
           
static void StreamIn.requestRanges(java.net.InetAddress source, java.lang.String tableName, java.util.Collection<ColumnFamilyStore> columnFamilies, java.util.Collection<Range<Token>> ranges, IStreamCallback callback, OperationType type)
          Request ranges to be transferred from specific CFs
static void StreamIn.requestRanges(java.net.InetAddress source, java.lang.String tableName, java.util.Collection<Range<Token>> ranges, IStreamCallback callback, OperationType type)
          Request ranges for all column families in the given keyspace.
static void StreamOut.transferRanges(java.net.InetAddress target, Table table, java.util.Collection<Range<Token>> ranges, IStreamCallback callback, OperationType type)
          Stream the given ranges to the target endpoint from each CF in the given keyspace.
static void StreamOut.transferRanges(StreamOutSession session, java.lang.Iterable<ColumnFamilyStore> cfses, java.util.Collection<Range<Token>> ranges, OperationType type)
          Stream the given ranges to the target endpoint from each of the given CFs.
static void StreamOut.transferSSTables(StreamOutSession session, java.lang.Iterable<SSTableReader> sstables, java.util.Collection<Range<Token>> ranges, OperationType type)
          Low-level transfer of matching portions of a group of sstables from a single table to the target endpoint.
 

Uses of Token in org.apache.cassandra.utils
 

Fields in org.apache.cassandra.utils declared as Token
 Token MerkleTree.RowHash.token
           
 

Fields in org.apache.cassandra.utils with type parameters of type Token
 Range<Token> MerkleTree.fullRange
          The top level range that this MerkleTree covers.
 

Methods in org.apache.cassandra.utils with parameters of type Token
 MerkleTree.TreeRange MerkleTree.get(Token t)
          For testing purposes.
 void MerkleTree.invalidate(Token t)
          Invalidates the ranges containing the given token.
 boolean MerkleTree.split(Token t)
          Splits the range containing the given token, if no tree limits would be violated.
 

Method parameters in org.apache.cassandra.utils with type arguments of type Token
 byte[] MerkleTree.hash(Range<Token> range)
          Hash the given range in the tree.
static void FBUtilities.sortSampledKeys(java.util.List<DecoratedKey> keys, Range<Token> range)
           
 

Constructors in org.apache.cassandra.utils with parameters of type Token
MerkleTree.RowHash(Token token, byte[] hash)
           
 

Constructor parameters in org.apache.cassandra.utils with type arguments of type Token
MerkleTree(IPartitioner partitioner, Range<Token> range, byte hashdepth, long maxsize)
           
 



Copyright © 2012 The Apache Software Foundation