A B C D E F G H I J K L M N O P Q R S T U V W X Y Z

A

A - Static variable in class org.apache.cassandra.cql.CqlLexer
 
A - Static variable in class org.apache.cassandra.cql.CqlParser
 
abortTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
absoluteFromFraction(double, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
AbstractBounds - Class in org.apache.cassandra.dht
 
AbstractBounds(Token, Token, IPartitioner) - Constructor for class org.apache.cassandra.dht.AbstractBounds
 
AbstractByteOrderedPartitioner - Class in org.apache.cassandra.dht
 
AbstractByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
AbstractCassandraDaemon - Class in org.apache.cassandra.service
The CassandraDaemon is an abstraction for a Cassandra daemon service, which defines not only a way to activate and deactivate it, but also hooks into its lifecycle methods (see AbstractCassandraDaemon.setup(), AbstractCassandraDaemon.start(), AbstractCassandraDaemon.stop() and AbstractCassandraDaemon.setup()).
AbstractCassandraDaemon() - Constructor for class org.apache.cassandra.service.AbstractCassandraDaemon
 
AbstractCassandraDaemon.CleaningThreadPool - Class in org.apache.cassandra.service
A subclass of Java's ThreadPoolExecutor which implements Jetty's ThreadPool interface (for integration with Avro), and performs ClientState cleanup.
AbstractCassandraDaemon.CleaningThreadPool(ThreadLocal<ClientState>, int, int) - Constructor for class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
AbstractColumnIterator - Class in org.apache.cassandra.db.filter
 
AbstractColumnIterator() - Constructor for class org.apache.cassandra.db.filter.AbstractColumnIterator
 
AbstractCommitLogExecutorService - Class in org.apache.cassandra.db.commitlog
 
AbstractCommitLogExecutorService() - Constructor for class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
AbstractCommutativeType - Class in org.apache.cassandra.db.marshal
 
AbstractCommutativeType() - Constructor for class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
AbstractCompactedRow - Class in org.apache.cassandra.io
a CompactedRow is an object that takes a bunch of rows (keys + columnfamilies) and can write a compacted version of those rows to an output stream.
AbstractCompactedRow(DecoratedKey) - Constructor for class org.apache.cassandra.io.AbstractCompactedRow
 
AbstractDataInput - Class in org.apache.cassandra.io.util
 
AbstractDataInput() - Constructor for class org.apache.cassandra.io.util.AbstractDataInput
 
AbstractEndpointSnitch - Class in org.apache.cassandra.locator
 
AbstractEndpointSnitch() - Constructor for class org.apache.cassandra.locator.AbstractEndpointSnitch
 
AbstractNetworkTopologySnitch - Class in org.apache.cassandra.locator
An endpoint snitch tells Cassandra information about network topology that it can use to route requests more efficiently.
AbstractNetworkTopologySnitch() - Constructor for class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
 
AbstractReplicationStrategy - Class in org.apache.cassandra.locator
A abstract parent for all replication strategies.
AbstractRowResolver - Class in org.apache.cassandra.service
 
AbstractRowResolver(ByteBuffer, String) - Constructor for class org.apache.cassandra.service.AbstractRowResolver
 
AbstractStatsDeque - Class in org.apache.cassandra.utils
 
AbstractStatsDeque() - Constructor for class org.apache.cassandra.utils.AbstractStatsDeque
 
AbstractType<T> - Class in org.apache.cassandra.db.marshal
Specifies a Comparator for a specific type of ByteBuffer.
AbstractType() - Constructor for class org.apache.cassandra.db.marshal.AbstractType
 
AbstractUUIDType - Class in org.apache.cassandra.db.marshal
 
AbstractUUIDType() - Constructor for class org.apache.cassandra.db.marshal.AbstractUUIDType
 
AbstractWriteResponseHandler - Class in org.apache.cassandra.service
 
AbstractWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel) - Constructor for class org.apache.cassandra.service.AbstractWriteResponseHandler
 
acceptImpl() - Method in class org.apache.cassandra.thrift.TCustomServerSocket
 
acceptsURL(String) - Method in class org.apache.cassandra.cql.jdbc.CassandraDriver
Method to validate whether provided connection url matches with pattern or not.
ACCESS_FILENAME_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthority
 
activate() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
A convenience method to initialize and start the daemon in one shot.
activate() - Method in interface org.apache.cassandra.service.CassandraDaemon
A convenience method to initialize and start the daemon in one shot.
adaptor - Variable in class org.apache.cassandra.cli.CliParser
 
add(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
add(CommitLog.LogRecordAdder) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
submits the adder for execution and blocks for it to be synced, if necessary
add(ColumnFamily) - Method in class org.apache.cassandra.db.RowMutation
 
add(QueryPath, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.RowMutation
 
add(QueryPath, ByteBuffer, long) - Method in class org.apache.cassandra.db.RowMutation
 
add(IMessageSink) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
add(AbstractCompactedRow) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
Called (in order) for every row present in the CF.
add(ByteBuffer, ColumnParent, CounterColumn, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
add(double) - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
 
add(double) - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
add(long) - Method in class org.apache.cassandra.utils.EstimatedHistogram
Increments the count of the bucket closest to n, rounding UP.
add(ByteBuffer) - Method in class org.apache.cassandra.utils.Filter
 
add(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
addAll(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
addAll(Iterator<MerkleTree.RowHash>) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addBatch() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
addBootstrapToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addColumn(Term, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Map a column name to a validator for its value
addColumn(IColumn) - Method in class org.apache.cassandra.db.Column
 
addColumn(QueryPath, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(QueryPath, ByteBuffer, long, int) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(ByteBuffer, Column) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(IColumn) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
addColumn(IColumn) - Method in interface org.apache.cassandra.db.IColumnContainer
 
addColumn(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
addColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
AddColumnFamily - Class in org.apache.cassandra.db.migration
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
AddColumnFamily() - Constructor for class org.apache.cassandra.db.migration.AddColumnFamily
Required no-arg constructor
AddColumnFamily(CFMetaData) - Constructor for class org.apache.cassandra.db.migration.AddColumnFamily
 
AddColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
AddColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
addColumnOrSuperColumn(String, ColumnOrSuperColumn) - Method in class org.apache.cassandra.db.RowMutation
 
addCounter(QueryPath, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addCounter(QueryPath, long) - Method in class org.apache.cassandra.db.RowMutation
 
addEntry(DecoratedKey, long) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
addFalsePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
addFiles(Collection<PendingFile>) - Method in class org.apache.cassandra.streaming.StreamInSession
 
addFilesToStream(List<PendingFile>) - Method in class org.apache.cassandra.streaming.StreamOutSession
 
addHash(MerkleTree.RowHash) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
addIndex(ColumnDefinition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
AddKeyspace - Class in org.apache.cassandra.db.migration
 
AddKeyspace() - Constructor for class org.apache.cassandra.db.migration.AddKeyspace
Required no-arg constructor
AddKeyspace(KSMetaData) - Constructor for class org.apache.cassandra.db.migration.AddKeyspace
 
AddKeyspace - Class in org.apache.cassandra.db.migration.avro
 
AddKeyspace() - Constructor for class org.apache.cassandra.db.migration.avro.AddKeyspace
 
addLatency(InetAddress, double) - Method in class org.apache.cassandra.net.MessagingService
 
addLeavingEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
addLocalApplicationState(ApplicationState, VersionedValue) - Method in class org.apache.cassandra.gms.Gossiper
 
addMicro(long) - Method in class org.apache.cassandra.utils.LatencyTracker
 
addMovingEndpoint(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Add a new moving endpoint
addNano(long) - Method in class org.apache.cassandra.utils.LatencyTracker
takes nanoseconds
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
Adds a position that would be a safe place for a segment boundary in the file.
addPotentialBoundary(long) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
Adds a position that would be a safe place for a segment boundary in the file.
addProperty(String, String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Map a keyword to the corresponding value
address - Variable in class org.apache.cassandra.dht.BootStrapper
 
addSavedEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Add an endpoint we knew about previously, but whose state is unknown
addSeed(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSeedProvider
 
addSSTable(SSTableReader) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
addSSTables(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
 
addStreamedSSTable(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
addTombstone(QueryPath, ByteBuffer, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addTombstone(QueryPath, int, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addTombstone(ByteBuffer, int, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addTruePositive() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.service.AbstractCassandraDaemon.CleaningThreadPool
 
AIOExecutorService - Class in org.apache.cassandra.concurrent
 
AIOExecutorService(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.AIOExecutorService
 
ALL - Static variable in enum org.apache.cassandra.auth.Permission
 
all() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
all() - Static method in class org.apache.cassandra.db.Table
 
allKeySamples() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
allocate(int, int) - Static method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
AllowAllAuthenticator - Class in org.apache.cassandra.auth
 
AllowAllAuthenticator() - Constructor for class org.apache.cassandra.auth.AllowAllAuthenticator
 
AllowAllAuthority - Class in org.apache.cassandra.auth
 
AllowAllAuthority() - Constructor for class org.apache.cassandra.auth.AllowAllAuthority
 
Alnum - Static variable in class org.apache.cassandra.cli.CliLexer
 
Alnum - Static variable in class org.apache.cassandra.cli.CliParser
 
alwaysMatchingBloomFilter() - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
AND - Static variable in class org.apache.cassandra.cli.CliLexer
 
AND - Static variable in class org.apache.cassandra.cli.CliParser
 
and(Term) - Method in class org.apache.cassandra.cql.SelectExpression
Add an additional column name to a SelectExpression.
and(Relation) - Method in class org.apache.cassandra.cql.WhereClause
Add an additional relation to this WHERE clause.
and(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
andNot(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
andNotCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of "a and not b" or "intersection(a, not(b))".
announce() - Method in class org.apache.cassandra.db.migration.Migration
 
announce(UUID, Set<InetAddress>) - Static method in class org.apache.cassandra.service.MigrationManager
actively announce my version to a set of hosts via rpc.
AntiEntropyService - Class in org.apache.cassandra.service
AntiEntropyService encapsulates "validating" (hashing) individual column families, exchanging MerkleTrees with remote nodes via a TreeRequest/Response conversation, and then triggering repairs for disagreeing ranges.
AntiEntropyService() - Constructor for class org.apache.cassandra.service.AntiEntropyService
Protected constructor.
AntiEntropyService.Differencer - Class in org.apache.cassandra.service
Runs on the node that initiated a request to compare two trees, and launch repairs for disagreeing ranges.
AntiEntropyService.Differencer(AntiEntropyService.TreeRequest, MerkleTree, MerkleTree) - Constructor for class org.apache.cassandra.service.AntiEntropyService.Differencer
 
AntiEntropyService.TreeRequest - Class in org.apache.cassandra.service
A tuple of table, cf, address and range that represents a location we have an outstanding TreeRequest for.
AntiEntropyService.TreeRequest(String, InetAddress, Range, AntiEntropyService.CFPair) - Constructor for class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
AntiEntropyService.TreeRequestVerbHandler - Class in org.apache.cassandra.service
Handler for requests from remote nodes to generate a valid tree.
AntiEntropyService.TreeRequestVerbHandler() - Constructor for class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
AntiEntropyService.TreeResponseVerbHandler - Class in org.apache.cassandra.service
Handler for responses from remote nodes which contain a valid tree.
AntiEntropyService.TreeResponseVerbHandler() - Constructor for class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
AntiEntropyService.Validator - Class in org.apache.cassandra.service
A Strategy to handle building and validating a merkle tree for a column family.
API_VERSION - Static variable in class org.apache.cassandra.cli.CliLexer
 
API_VERSION - Static variable in class org.apache.cassandra.cli.CliParser
 
append(AbstractCompactedRow) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
append(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
append(DecoratedKey, ByteBuffer) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
ApplicationState - Enum in org.apache.cassandra.gms
 
apply(CfDef) - Method in class org.apache.cassandra.config.CFMetaData
 
apply() - Method in class org.apache.cassandra.db.CounterMutation
 
apply() - Method in class org.apache.cassandra.db.migration.Migration
apply changes
apply() - Method in class org.apache.cassandra.db.RowMutation
 
apply(RowMutation, boolean) - Method in class org.apache.cassandra.db.Table
This method adds the row to the Commit Log associated with this table.
apply() - Method in class org.apache.cassandra.db.Truncation
This is equivalent to calling commit.
apply(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
applyCounterMutationOnCoordinator(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
 
applyCounterMutationOnLeader(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
 
applyImplicitDefaults(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
applies implicit defaults to cf definition.
applyMigrations(UUID, UUID) - Static method in class org.apache.cassandra.service.MigrationManager
gets called during startup if we notice a mismatch between the current migration version and the one saved.
applyModels() - Method in class org.apache.cassandra.db.migration.AddColumnFamily
 
applyModels() - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
applyModels() - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
applyModels() - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
applyModels() - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
applyModels() - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
applyUnsafe() - Method in class org.apache.cassandra.db.RowMutation
 
ARRAY - Static variable in class org.apache.cassandra.cli.CliLexer
 
ARRAY - Static variable in class org.apache.cassandra.cli.CliParser
 
arrayConstruct() - Method in class org.apache.cassandra.cli.CliParser
 
arrayCopy(ByteBuffer, int, byte[], int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
arrayCopy(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Transfer bytes from one ByteBuffer to another.
asByteArray() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
 
asByteArray() - Method in class org.apache.cassandra.io.util.OutputBuffer
 
AsciiType - Class in org.apache.cassandra.db.marshal
 
ASSUME - Static variable in class org.apache.cassandra.cli.CliLexer
 
ASSUME - Static variable in class org.apache.cassandra.cli.CliParser
 
assumeStatement() - Method in class org.apache.cassandra.cli.CliParser
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
assureSufficientLiveNodes() - Method in interface org.apache.cassandra.service.IWriteResponseHandler
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.ReadCallback
 
assureSufficientLiveNodes() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
asTemporary(boolean) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
AsyncRepairCallback - Class in org.apache.cassandra.service
 
AsyncRepairCallback(RowRepairResolver, int) - Constructor for class org.apache.cassandra.service.AsyncRepairCallback
 
atomicSetMax(AtomicInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
atomicSetMax(AtomicLong, long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
attr_name() - Method in class org.apache.cassandra.cli.CliParser
 
attrValue() - Method in class org.apache.cassandra.cli.CliParser
 
attrValueDouble() - Method in class org.apache.cassandra.cli.CliParser
 
attrValueInt() - Method in class org.apache.cassandra.cli.CliParser
 
attrValueString() - Method in class org.apache.cassandra.cli.CliParser
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in interface org.apache.cassandra.auth.IAuthenticator
 
authenticate(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.auth.SimpleAuthenticator
 
AuthenticatedUser - Class in org.apache.cassandra.auth
An authenticated user and her groups.
AuthenticatedUser(String) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
 
AuthenticatedUser(String, Set<String>) - Constructor for class org.apache.cassandra.auth.AuthenticatedUser
 
authenticator - Variable in class org.apache.cassandra.config.Config
 
authority - Variable in class org.apache.cassandra.config.Config
 
authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.AllowAllAuthority
 
authorize(AuthenticatedUser, List<Object>) - Method in interface org.apache.cassandra.auth.IAuthority
 
authorize(AuthenticatedUser, List<Object>) - Method in class org.apache.cassandra.auth.SimpleAuthority
 
auto_bootstrap - Variable in class org.apache.cassandra.config.Config
 
AutoSavingCache<K,V> - Class in org.apache.cassandra.cache
 
AutoSavingCache(ICache<K, V>, String, String, ColumnFamilyStore.CacheType) - Constructor for class org.apache.cassandra.cache.AutoSavingCache
 
AutoSavingCache.Writer - Class in org.apache.cassandra.cache
 
AutoSavingKeyCache<K extends Pair<Descriptor,DecoratedKey>,V> - Class in org.apache.cassandra.cache
 
AutoSavingKeyCache(ICache<K, V>, String, String) - Constructor for class org.apache.cassandra.cache.AutoSavingKeyCache
 
AutoSavingRowCache<K extends DecoratedKey,V> - Class in org.apache.cassandra.cache
 
AutoSavingRowCache(ICache<K, V>, String, String) - Constructor for class org.apache.cassandra.cache.AutoSavingRowCache
 
await() - Method in class org.apache.cassandra.utils.SimpleCondition
 
await(long, TimeUnit) - Method in class org.apache.cassandra.utils.SimpleCondition
 
awaitNanos(long) - Method in class org.apache.cassandra.utils.SimpleCondition
 
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
awaitTermination() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
Blocks until shutdown is complete.
awaitUninterruptibly() - Method in class org.apache.cassandra.utils.SimpleCondition
 
awaitUntil(Date) - Method in class org.apache.cassandra.utils.SimpleCondition
 

B

B - Static variable in class org.apache.cassandra.cql.CqlLexer
 
B - Static variable in class org.apache.cassandra.cql.CqlParser
 
banner - Variable in class org.apache.cassandra.cli.CliUserHelp
 
batch - Variable in class org.apache.cassandra.cli.CliSessionState
 
batch_mutate(Map<ByteBuffer, Map<String, List<Mutation>>>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
BATCH_THRESHOLD - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
 
BatchCommitLogExecutorServiceMBean - Interface in org.apache.cassandra.db.commitlog
 
BatchUpdateStatement - Class in org.apache.cassandra.cql
A BATCH UPDATE statement parsed from a CQL query.
BatchUpdateStatement(List<UpdateStatement>, ConsistencyLevel) - Constructor for class org.apache.cassandra.cql.BatchUpdateStatement
Creates a new BatchUpdateStatement from a list of UpdateStatements and a Thrift consistency level.
batchUpdateStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
begin() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
BigIntegerToken - Class in org.apache.cassandra.dht
 
BigIntegerToken(BigInteger) - Constructor for class org.apache.cassandra.dht.BigIntegerToken
 
BigIntegerToken(String) - Constructor for class org.apache.cassandra.dht.BigIntegerToken
 
binary_memtable_throughput_in_mb - Variable in class org.apache.cassandra.config.Config
 
BinaryMemtable - Class in org.apache.cassandra.db
 
BinaryMemtable(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.BinaryMemtable
 
BinaryVerbHandler - Class in org.apache.cassandra.db
 
BinaryVerbHandler() - Constructor for class org.apache.cassandra.db.BinaryVerbHandler
 
bind() - Method in class org.apache.cassandra.security.streaming.SSLFileStreamTask
 
bind() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
bits - Variable in class org.apache.cassandra.utils.obs.OpenBitSet
 
bits2words(long) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
returns the number of 64 bit words it would take to hold numBits
bitset - Variable in class org.apache.cassandra.utils.BloomFilter
 
blockfor - Variable in class org.apache.cassandra.service.ReadCallback
 
BloomFilter - Class in org.apache.cassandra.utils
 
BloomFilterTracker - Class in org.apache.cassandra.io.sstable
 
BloomFilterTracker() - Constructor for class org.apache.cassandra.io.sstable.BloomFilterTracker
 
boolSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
bootstrap() - Method in class org.apache.cassandra.dht.BootStrapper
 
BootStrapper - Class in org.apache.cassandra.dht
 
BootStrapper(InetAddress, Token, TokenMetadata) - Constructor for class org.apache.cassandra.dht.BootStrapper
 
BootStrapper.BootstrapTokenVerbHandler - Class in org.apache.cassandra.dht
 
BootStrapper.BootstrapTokenVerbHandler() - Constructor for class org.apache.cassandra.dht.BootStrapper.BootstrapTokenVerbHandler
 
bootstrapping(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
BoundedStatsDeque - Class in org.apache.cassandra.utils
not threadsafe.
BoundedStatsDeque(int) - Constructor for class org.apache.cassandra.utils.BoundedStatsDeque
 
Bounds - Class in org.apache.cassandra.dht
 
Bounds(Token, Token) - Constructor for class org.apache.cassandra.dht.Bounds
 
BufferedRandomAccessFile - Class in org.apache.cassandra.io.util
A BufferedRandomAccessFile is like a RandomAccessFile, but it uses a private buffer so that most operations do not require a disk access.
BufferedRandomAccessFile(String, String) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(String, String, int) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(File, String) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(File, String, int) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile(File, String, int, boolean) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
BufferedRandomAccessFile.BufferedRandomAccessFileMark - Class in org.apache.cassandra.io.util
Class to hold a mark to the position of the file
BufferedRandomAccessFile.BufferedRandomAccessFileMark(long) - Constructor for class org.apache.cassandra.io.util.BufferedRandomAccessFile.BufferedRandomAccessFileMark
 
BufferedSegmentedFile - Class in org.apache.cassandra.io.util
 
BufferedSegmentedFile(String, long) - Constructor for class org.apache.cassandra.io.util.BufferedSegmentedFile
 
BufferedSegmentedFile.Builder - Class in org.apache.cassandra.io.util
 
BufferedSegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
 
bufIn_ - Variable in class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
bufOut_ - Variable in class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
build() - Method in class org.apache.cassandra.db.Table.IndexBuilder
 
build() - Method in class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
buildSecondaryIndexes(Collection<SSTableReader>, SortedSet<ByteBuffer>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
BY - Static variable in class org.apache.cassandra.cli.CliLexer
 
BY - Static variable in class org.apache.cassandra.cli.CliParser
 
BYTE_MASK - Static variable in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
ByteBufferUtil - Class in org.apache.cassandra.utils
Utility methods to make ByteBuffers less painful The following should illustrate the different ways byte buffers can be used public void testArrayOffet() { byte[] b = "test_slice_array".getBytes(); ByteBuffer bb = ByteBuffer.allocate(1024); assert bb.position() == 0; assert bb.limit() == 1024; assert bb.capacity() == 1024; bb.put(b); assert bb.position() == b.length; assert bb.remaining() == bb.limit() - bb.position(); ByteBuffer bb2 = bb.slice(); assert bb2.position() == 0; //slice should begin at other buffers current position assert bb2.arrayOffset() == bb.position(); //to match the position in the underlying array one needs to //track arrayOffset assert bb2.limit()+bb2.arrayOffset() == bb.limit(); assert bb2.remaining() == bb.remaining(); } }
ByteBufferUtil() - Constructor for class org.apache.cassandra.utils.ByteBufferUtil
 
ByteOrderedPartitioner - Class in org.apache.cassandra.dht
 
ByteOrderedPartitioner() - Constructor for class org.apache.cassandra.dht.ByteOrderedPartitioner
 
bytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Encode a String in a ByteBuffer using UTF_8.
bytes(String, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Encode a String in a ByteBuffer using the provided charset.
bytes(int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(long) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(float) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes(double) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytes() - Method in class org.apache.cassandra.utils.NodeId
 
bytesCompare(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.db.marshal.BytesType
 
bytesOnDisk() - Method in class org.apache.cassandra.io.sstable.SSTable
 
bytesPastMark() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
bytesPastMark(FileMark) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
bytesPastMark(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesPastMark(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
bytesRemaining() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
bytesRemaining() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
bytesToHex(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
bytesToHex(byte...) - Static method in class org.apache.cassandra.utils.FBUtilities
 
BytesToken - Class in org.apache.cassandra.dht
 
BytesToken(ByteBuffer) - Constructor for class org.apache.cassandra.dht.BytesToken
 
BytesToken(byte[]) - Constructor for class org.apache.cassandra.dht.BytesToken
 
BytesType - Class in org.apache.cassandra.db.marshal
 

C

C - Static variable in class org.apache.cassandra.cql.CqlLexer
 
C - Static variable in class org.apache.cassandra.cql.CqlParser
 
cacheEndpoint(Token, ArrayList<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
cacheKey(DecoratedKey, Long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
cacheType - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
CachingMessageProducer - Class in org.apache.cassandra.net
 
CachingMessageProducer(MessageProducer) - Constructor for class org.apache.cassandra.net.CachingMessageProducer
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
calculate the natural endpoints for the given token
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.LocalStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
calculateNaturalEndpoints(Token, TokenMetadata) - Method in class org.apache.cassandra.locator.SimpleStrategy
 
calculatePendingRanges(AbstractReplicationStrategy, String) - Static method in class org.apache.cassandra.service.StorageService
 
capacity() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
capacity() - Method in interface org.apache.cassandra.cache.ICache
 
capacity() - Method in class org.apache.cassandra.cache.SerializingCache
 
capacity() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the current capacity in bits (1 greater than the index of the last bit)
cardinality() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
CassandraDaemon - Interface in org.apache.cassandra.service
The CassandraDaemon interface captures the lifecycle of a Cassandra daemon that runs on a single node.
CassandraDaemon - Class in org.apache.cassandra.thrift
This class supports two methods for creating a Cassandra node daemon, invoking the class's main method, and using the jsvc wrapper from commons-daemon, (for more information on using this class with the jsvc wrapper, see the Commons Daemon documentation).
CassandraDaemon() - Constructor for class org.apache.cassandra.thrift.CassandraDaemon
 
CassandraDriver - Class in org.apache.cassandra.cql.jdbc
The Class CassandraDriver.
CassandraDriver() - Constructor for class org.apache.cassandra.cql.jdbc.CassandraDriver
 
CassandraPreparedStatement - Class in org.apache.cassandra.cql.jdbc
 
CassandraResultSet - Interface in org.apache.cassandra.cql.jdbc
 
CassandraServer - Class in org.apache.cassandra.thrift
 
CassandraServer() - Constructor for class org.apache.cassandra.thrift.CassandraServer
 
cf - Variable in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
cf - Variable in class org.apache.cassandra.db.Row
 
cf - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
cf_defs - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
CfDef - Class in org.apache.cassandra.db.migration.avro
 
CfDef() - Constructor for class org.apache.cassandra.db.migration.avro.CfDef
 
cfId - Variable in class org.apache.cassandra.config.CFMetaData
 
cfid - Variable in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
cfId - Variable in exception org.apache.cassandra.db.UnserializableColumnFamilyException
 
CFMetaData - Class in org.apache.cassandra.config
 
CFMetaData(String, String, ColumnFamilyType, AbstractType, AbstractType) - Constructor for class org.apache.cassandra.config.CFMetaData
 
cfMetaData() - Method in class org.apache.cassandra.config.KSMetaData
 
cfName - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
cfName - Variable in class org.apache.cassandra.config.CFMetaData
 
cfname - Variable in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
cfname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
cfs - Variable in class org.apache.cassandra.db.Memtable
 
cfstore - Variable in class org.apache.cassandra.db.DataTracker
 
cfType - Variable in class org.apache.cassandra.config.CFMetaData
 
CHAR_MASK - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
CharacterEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
checkAllColumnFamilies() - Method in class org.apache.cassandra.db.CompactionManager
 
checkHealth() - Static method in class org.apache.cassandra.db.SystemTable
One of three things will happen if you try to read the system table: 1.
checkOutputSpecs(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Check for validity of the output-specification for the job.
checkOutputSpecs(FileSystem, JobConf) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated. 
CHUNK_SIZE - Static variable in class org.apache.cassandra.streaming.FileStreamTask
 
cipherSuites - Variable in class org.apache.cassandra.config.EncryptionOptions
 
class_name - Variable in class org.apache.cassandra.config.SeedProviderDef
 
classForName(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
classname - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
cleanup() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
cleanupIndexEntry(ColumnFamilyStore, ByteBuffer, IColumn) - Static method in class org.apache.cassandra.db.Table
 
cleanupJob(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
clear() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
clear() - Method in interface org.apache.cassandra.cache.ICache
 
clear() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
clear() - Method in class org.apache.cassandra.cache.SerializingCache
 
clear() - Method in class org.apache.cassandra.db.ColumnFamily
 
clear(String) - Static method in class org.apache.cassandra.db.Table
 
clear() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
clear() - Static method in class org.apache.cassandra.net.sink.SinkManager
 
clear() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
clear() - Method in class org.apache.cassandra.utils.BloomFilter
 
clear() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
clear() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
clear(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit, allowing access beyond the current set size without changing the size.
clear(int, int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Clears a range of bits.
clear(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Clears a range of bits.
clearAllDelta(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Remove all the delta of a context (i.e, set an empty header).
clearEndpointCache() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
clearParameters() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
clearSnapshot(String) - Method in class org.apache.cassandra.db.Table
Clear all the snapshots for a given table.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Remove the snapshot with the given name from the given tables.
clearSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Remove the snapshot with the given name from the given tables.
clearSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Remove all the existing snapshots.
clearTableDefinition(KSMetaData, UUID) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
clearUnsafe() - Method in class org.apache.cassandra.locator.TokenMetadata
used by tests
CLibrary - Class in org.apache.cassandra.utils
 
CliClient - Class in org.apache.cassandra.cli
 
CliClient(CliSessionState, Cassandra.Client) - Constructor for class org.apache.cassandra.cli.CliClient
 
CliClient.ColumnFamilyArgument - Enum in org.apache.cassandra.cli
 
CliClient.Function - Enum in org.apache.cassandra.cli
Available value conversion functions Used by convertValueByFunction(Tree functionCall) method
CliCommandHelp - Class in org.apache.cassandra.cli
 
CliCommandHelp() - Constructor for class org.apache.cassandra.cli.CliCommandHelp
 
CliCompiler - Class in org.apache.cassandra.cli
 
CliCompiler() - Constructor for class org.apache.cassandra.cli.CliCompiler
 
CliCompiler.ANTLRNoCaseStringStream - Class in org.apache.cassandra.cli
 
CliCompiler.ANTLRNoCaseStringStream(String) - Constructor for class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
 
CliCompleter - Class in org.apache.cassandra.cli
 
CliCompleter() - Constructor for class org.apache.cassandra.cli.CliCompleter
 
clientMode - Variable in class org.apache.cassandra.db.migration.Migration
 
ClientState - Class in org.apache.cassandra.service
A container for per-client, thread-local state that Avro/Thrift threads must hold.
ClientState() - Constructor for class org.apache.cassandra.service.ClientState
Construct a new, empty ClientState: can be reused after logout() or reset().
clientState - Variable in class org.apache.cassandra.thrift.CassandraServer
 
CliLexer - Class in org.apache.cassandra.cli
 
CliLexer() - Constructor for class org.apache.cassandra.cli.CliLexer
 
CliLexer(CharStream) - Constructor for class org.apache.cassandra.cli.CliLexer
 
CliLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliLexer
 
CliMain - Class in org.apache.cassandra.cli
Cassandra Command Line Interface (CLI) Main
CliMain() - Constructor for class org.apache.cassandra.cli.CliMain
 
CliOptions - Class in org.apache.cassandra.cli
Used to process, and act upon the arguments passed to the CLI.
CliOptions() - Constructor for class org.apache.cassandra.cli.CliOptions
 
CliParser - Class in org.apache.cassandra.cli
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
CliParser(TokenStream) - Constructor for class org.apache.cassandra.cli.CliParser
 
CliParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cli.CliParser
 
CliParser.addColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.addColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.addColumnFamily_return
 
CliParser.addKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.addKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.addKeyspace_return
 
CliParser.arrayConstruct_return - Class in org.apache.cassandra.cli
 
CliParser.arrayConstruct_return() - Constructor for class org.apache.cassandra.cli.CliParser.arrayConstruct_return
 
CliParser.assumeStatement_return - Class in org.apache.cassandra.cli
 
CliParser.assumeStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.assumeStatement_return
 
CliParser.attr_name_return - Class in org.apache.cassandra.cli
 
CliParser.attr_name_return() - Constructor for class org.apache.cassandra.cli.CliParser.attr_name_return
 
CliParser.attrValue_return - Class in org.apache.cassandra.cli
 
CliParser.attrValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValue_return
 
CliParser.attrValueDouble_return - Class in org.apache.cassandra.cli
 
CliParser.attrValueDouble_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueDouble_return
 
CliParser.attrValueInt_return - Class in org.apache.cassandra.cli
 
CliParser.attrValueInt_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueInt_return
 
CliParser.attrValueString_return - Class in org.apache.cassandra.cli
 
CliParser.attrValueString_return() - Constructor for class org.apache.cassandra.cli.CliParser.attrValueString_return
 
CliParser.columnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.columnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamily_return
 
CliParser.columnFamilyExpr_return - Class in org.apache.cassandra.cli
 
CliParser.columnFamilyExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
 
CliParser.columnName_return - Class in org.apache.cassandra.cli
 
CliParser.columnName_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnName_return
 
CliParser.columnOrSuperColumn_return - Class in org.apache.cassandra.cli
 
CliParser.columnOrSuperColumn_return() - Constructor for class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
 
CliParser.command_return - Class in org.apache.cassandra.cli
 
CliParser.command_return() - Constructor for class org.apache.cassandra.cli.CliParser.command_return
 
CliParser.comparator_return - Class in org.apache.cassandra.cli
 
CliParser.comparator_return() - Constructor for class org.apache.cassandra.cli.CliParser.comparator_return
 
CliParser.connectStatement_return - Class in org.apache.cassandra.cli
 
CliParser.connectStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.connectStatement_return
 
CliParser.consistencyLevelStatement_return - Class in org.apache.cassandra.cli
 
CliParser.consistencyLevelStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
 
CliParser.countStatement_return - Class in org.apache.cassandra.cli
 
CliParser.countStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.countStatement_return
 
CliParser.delColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.delColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.delColumnFamily_return
 
CliParser.delKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.delKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.delKeyspace_return
 
CliParser.delStatement_return - Class in org.apache.cassandra.cli
 
CliParser.delStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.delStatement_return
 
CliParser.describeCluster_return - Class in org.apache.cassandra.cli
 
CliParser.describeCluster_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeCluster_return
 
CliParser.describeTable_return - Class in org.apache.cassandra.cli
 
CliParser.describeTable_return() - Constructor for class org.apache.cassandra.cli.CliParser.describeTable_return
 
CliParser.endKey_return - Class in org.apache.cassandra.cli
 
CliParser.endKey_return() - Constructor for class org.apache.cassandra.cli.CliParser.endKey_return
 
CliParser.exitStatement_return - Class in org.apache.cassandra.cli
 
CliParser.exitStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.exitStatement_return
 
CliParser.functionArgument_return - Class in org.apache.cassandra.cli
 
CliParser.functionArgument_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionArgument_return
 
CliParser.functionCall_return - Class in org.apache.cassandra.cli
 
CliParser.functionCall_return() - Constructor for class org.apache.cassandra.cli.CliParser.functionCall_return
 
CliParser.getCondition_return - Class in org.apache.cassandra.cli
 
CliParser.getCondition_return() - Constructor for class org.apache.cassandra.cli.CliParser.getCondition_return
 
CliParser.getStatement_return - Class in org.apache.cassandra.cli
 
CliParser.getStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.getStatement_return
 
CliParser.hashConstruct_return - Class in org.apache.cassandra.cli
 
CliParser.hashConstruct_return() - Constructor for class org.apache.cassandra.cli.CliParser.hashConstruct_return
 
CliParser.hashElementPair_return - Class in org.apache.cassandra.cli
 
CliParser.hashElementPair_return() - Constructor for class org.apache.cassandra.cli.CliParser.hashElementPair_return
 
CliParser.helpStatement_return - Class in org.apache.cassandra.cli
 
CliParser.helpStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.helpStatement_return
 
CliParser.host_name_return - Class in org.apache.cassandra.cli
 
CliParser.host_name_return() - Constructor for class org.apache.cassandra.cli.CliParser.host_name_return
 
CliParser.host_return - Class in org.apache.cassandra.cli
 
CliParser.host_return() - Constructor for class org.apache.cassandra.cli.CliParser.host_return
 
CliParser.incrementValue_return - Class in org.apache.cassandra.cli
 
CliParser.incrementValue_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrementValue_return
 
CliParser.incrStatement_return - Class in org.apache.cassandra.cli
 
CliParser.incrStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.incrStatement_return
 
CliParser.ip_address_return - Class in org.apache.cassandra.cli
 
CliParser.ip_address_return() - Constructor for class org.apache.cassandra.cli.CliParser.ip_address_return
 
CliParser.keyRangeExpr_return - Class in org.apache.cassandra.cli
 
CliParser.keyRangeExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyRangeExpr_return
 
CliParser.keyspace_return - Class in org.apache.cassandra.cli
 
CliParser.keyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyspace_return
 
CliParser.keyspaceNewName_return - Class in org.apache.cassandra.cli
 
CliParser.keyspaceNewName_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyspaceNewName_return
 
CliParser.keyValuePair_return - Class in org.apache.cassandra.cli
 
CliParser.keyValuePair_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyValuePair_return
 
CliParser.keyValuePairExpr_return - Class in org.apache.cassandra.cli
 
CliParser.keyValuePairExpr_return() - Constructor for class org.apache.cassandra.cli.CliParser.keyValuePairExpr_return
 
CliParser.listStatement_return - Class in org.apache.cassandra.cli
 
CliParser.listStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.listStatement_return
 
CliParser.newColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.newColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.newColumnFamily_return
 
CliParser.objectName_return - Class in org.apache.cassandra.cli
 
CliParser.objectName_return() - Constructor for class org.apache.cassandra.cli.CliParser.objectName_return
 
CliParser.operator_return - Class in org.apache.cassandra.cli
 
CliParser.operator_return() - Constructor for class org.apache.cassandra.cli.CliParser.operator_return
 
CliParser.password_return - Class in org.apache.cassandra.cli
 
CliParser.password_return() - Constructor for class org.apache.cassandra.cli.CliParser.password_return
 
CliParser.port_return - Class in org.apache.cassandra.cli
 
CliParser.port_return() - Constructor for class org.apache.cassandra.cli.CliParser.port_return
 
CliParser.replica_placement_strategy_return - Class in org.apache.cassandra.cli
 
CliParser.replica_placement_strategy_return() - Constructor for class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
 
CliParser.root_return - Class in org.apache.cassandra.cli
 
CliParser.root_return() - Constructor for class org.apache.cassandra.cli.CliParser.root_return
 
CliParser.rowKey_return - Class in org.apache.cassandra.cli
 
CliParser.rowKey_return() - Constructor for class org.apache.cassandra.cli.CliParser.rowKey_return
 
CliParser.setStatement_return - Class in org.apache.cassandra.cli
 
CliParser.setStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.setStatement_return
 
CliParser.showClusterName_return - Class in org.apache.cassandra.cli
 
CliParser.showClusterName_return() - Constructor for class org.apache.cassandra.cli.CliParser.showClusterName_return
 
CliParser.showKeyspaces_return - Class in org.apache.cassandra.cli
 
CliParser.showKeyspaces_return() - Constructor for class org.apache.cassandra.cli.CliParser.showKeyspaces_return
 
CliParser.showStatement_return - Class in org.apache.cassandra.cli
 
CliParser.showStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.showStatement_return
 
CliParser.showVersion_return - Class in org.apache.cassandra.cli
 
CliParser.showVersion_return() - Constructor for class org.apache.cassandra.cli.CliParser.showVersion_return
 
CliParser.startKey_return - Class in org.apache.cassandra.cli
 
CliParser.startKey_return() - Constructor for class org.apache.cassandra.cli.CliParser.startKey_return
 
CliParser.statement_return - Class in org.apache.cassandra.cli
 
CliParser.statement_return() - Constructor for class org.apache.cassandra.cli.CliParser.statement_return
 
CliParser.truncateStatement_return - Class in org.apache.cassandra.cli
 
CliParser.truncateStatement_return() - Constructor for class org.apache.cassandra.cli.CliParser.truncateStatement_return
 
CliParser.typeIdentifier_return - Class in org.apache.cassandra.cli
 
CliParser.typeIdentifier_return() - Constructor for class org.apache.cassandra.cli.CliParser.typeIdentifier_return
 
CliParser.updateColumnFamily_return - Class in org.apache.cassandra.cli
 
CliParser.updateColumnFamily_return() - Constructor for class org.apache.cassandra.cli.CliParser.updateColumnFamily_return
 
CliParser.updateKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.updateKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.updateKeyspace_return
 
CliParser.useKeyspace_return - Class in org.apache.cassandra.cli
 
CliParser.useKeyspace_return() - Constructor for class org.apache.cassandra.cli.CliParser.useKeyspace_return
 
CliParser.username_return - Class in org.apache.cassandra.cli
 
CliParser.username_return() - Constructor for class org.apache.cassandra.cli.CliParser.username_return
 
CliParser.value_return - Class in org.apache.cassandra.cli
 
CliParser.value_return() - Constructor for class org.apache.cassandra.cli.CliParser.value_return
 
CliSessionState - Class in org.apache.cassandra.cli
Used to hold the state for the CLI.
CliSessionState() - Constructor for class org.apache.cassandra.cli.CliSessionState
 
CliUserHelp - Class in org.apache.cassandra.cli
 
CliUserHelp() - Constructor for class org.apache.cassandra.cli.CliUserHelp
 
CliUtils - Class in org.apache.cassandra.cli
 
CliUtils() - Constructor for class org.apache.cassandra.cli.CliUtils
 
clone(ByteBuffer) - Method in class org.apache.cassandra.db.MemtableAllocator
Allocate a slice of the given length.
clone(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
clone() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
cloneAfterAllLeft() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all current leave operations have finished.
cloneAfterAllSettled() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with tokenToEndpointMap reflecting situation after all current leave and move operations have finished.
cloneMe() - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMe() - Method in class org.apache.cassandra.db.SuperColumn
 
cloneMeShallow() - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMeShallow() - Method in class org.apache.cassandra.db.SuperColumn
 
cloneOnlyTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
Create a copy of TokenMetadata with only tokenToEndpointMap.
close() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
close() - Method in interface org.apache.cassandra.db.columniterator.IColumnIterator
clean up any open resources
close() - Method in class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
 
close() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
close() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
close() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
close() - Method in class org.apache.cassandra.db.RowIterator
 
close() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
close() - Method in class org.apache.cassandra.io.CompactionIterator
 
close() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
close() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
close() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
close() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
close() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
close(Iterable<? extends Closeable>) - Static method in class org.apache.cassandra.io.util.FileUtils
 
close() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
close() - Method in class org.apache.cassandra.security.streaming.SSLFileStreamTask
 
close() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
close() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
close() - Method in class org.apache.cassandra.tools.NodeProbe
 
CloseableIterator<T> - Interface in org.apache.cassandra.utils
 
closeAndOpenReader() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
closeAndOpenReader(long) - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
closeIfFinished() - Method in class org.apache.cassandra.streaming.StreamInSession
 
closeQuietly(Closeable) - Static method in class org.apache.cassandra.io.util.FileUtils
 
cluster_name - Variable in class org.apache.cassandra.config.Config
 
CMD_TYPE_GET_SLICE - Static variable in class org.apache.cassandra.db.ReadCommand
 
CMD_TYPE_GET_SLICE_BY_NAMES - Static variable in class org.apache.cassandra.db.ReadCommand
 
CollatingOrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
CollatingOrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
collectCollatedColumns(ColumnFamily, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in interface org.apache.cassandra.db.filter.IFilter
collects columns from reducedColumns into returnCF.
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
COLUMN - Static variable in class org.apache.cassandra.cli.CliLexer
 
COLUMN - Static variable in class org.apache.cassandra.cli.CliParser
 
Column - Class in org.apache.cassandra.db
Column is immutable, which prevents all kinds of confusion in a multithreaded environment.
Column(ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.Column
 
Column(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.Column
 
column(ByteBuffer) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
column_family - Variable in class org.apache.cassandra.db.IndexScanCommand
 
column_family - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
column_index_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
column_metadata - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
column_type - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
columnComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
columnCount() - Method in class org.apache.cassandra.io.AbstractCompactedRow
 
columnCount() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
columnCount() - Method in class org.apache.cassandra.io.PrecompactedRow
 
columnCount - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
ColumnDef - Class in org.apache.cassandra.db.migration.avro
 
ColumnDef() - Constructor for class org.apache.cassandra.db.migration.avro.ColumnDef
 
ColumnDefinition - Class in org.apache.cassandra.config
 
ColumnDefinition(ByteBuffer, AbstractType, IndexType, String) - Constructor for class org.apache.cassandra.config.ColumnDefinition
 
columnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
ColumnFamily - Class in org.apache.cassandra.db
 
ColumnFamily(CFMetaData) - Constructor for class org.apache.cassandra.db.ColumnFamily
 
columnFamily - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
columnFamily - Variable in class org.apache.cassandra.db.TruncateResponse
 
columnFamily - Variable in class org.apache.cassandra.db.Truncation
 
columnFamilyExpr() - Method in class org.apache.cassandra.cli.CliParser
 
ColumnFamilyInputFormat - Class in org.apache.cassandra.hadoop
Hadoop InputFormat allowing map/reduce against Cassandra rows within one ColumnFamily.
ColumnFamilyInputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
columnFamilyName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
ColumnFamilyNotDefinedException - Exception in org.apache.cassandra.db
 
ColumnFamilyNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.ColumnFamilyNotDefinedException
 
ColumnFamilyOutputFormat - Class in org.apache.cassandra.hadoop
The ColumnFamilyOutputFormat acts as a Hadoop-specific OutputFormat that allows reduce tasks to store keys (and corresponding values) as Cassandra rows (and respective columns) in a given ColumnFamily.
ColumnFamilyOutputFormat() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
 
ColumnFamilyOutputFormat.NullOutputCommitter - Class in org.apache.cassandra.hadoop
An OutputCommitter that does nothing.
ColumnFamilyOutputFormat.NullOutputCommitter() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
ColumnFamilyRecordReader - Class in org.apache.cassandra.hadoop
 
ColumnFamilyRecordReader() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
ColumnFamilySerializer - Class in org.apache.cassandra.db
 
ColumnFamilySerializer() - Constructor for class org.apache.cassandra.db.ColumnFamilySerializer
 
ColumnFamilySplit - Class in org.apache.cassandra.hadoop
 
ColumnFamilySplit(String, String, String[]) - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilySplit() - Constructor for class org.apache.cassandra.hadoop.ColumnFamilySplit
 
ColumnFamilyStore - Class in org.apache.cassandra.db
 
ColumnFamilyStore.CacheType - Enum in org.apache.cassandra.db
 
ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
The MBean interface for ColumnFamilyStore
ColumnFamilyType - Enum in org.apache.cassandra.db
column family type enum
ColumnIndexer - Class in org.apache.cassandra.db
Help to create an index for a column family based on size of columns
ColumnIndexer() - Constructor for class org.apache.cassandra.db.ColumnIndexer
 
columnMetadata(Map<ByteBuffer, ColumnDefinition>) - Method in class org.apache.cassandra.config.CFMetaData
 
columnName() - Method in class org.apache.cassandra.cli.CliParser
 
columnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
columnNames - Variable in class org.apache.cassandra.db.SliceByNamesReadCommand
 
columnOrSuperColumn() - Method in class org.apache.cassandra.cli.CliParser
 
columnReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
columns - Variable in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
 
ColumnSerializer - Class in org.apache.cassandra.db
 
ColumnSerializer() - Constructor for class org.apache.cassandra.db.ColumnSerializer
 
ColumnSortedMap - Class in org.apache.cassandra.io.util
Facade over a DataInput that contains IColumns in sorted order.
ColumnSortedMap(Comparator<ByteBuffer>, ColumnSerializer, DataInput, ColumnFamilyStore, int, boolean, int) - Constructor for class org.apache.cassandra.io.util.ColumnSortedMap
 
command() - Method in class org.apache.cassandra.cli.CliParser
 
commands - Variable in class org.apache.cassandra.cli.CliUserHelp
 
commandType - Variable in class org.apache.cassandra.db.ReadCommand
 
COMMENT - Static variable in class org.apache.cassandra.cli.CliLexer
 
COMMENT - Static variable in class org.apache.cassandra.cli.CliParser
 
comment(String) - Method in class org.apache.cassandra.config.CFMetaData
 
COMMENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
comment - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
CommitLog - Class in org.apache.cassandra.db.commitlog
 
commitlog_directory - Variable in class org.apache.cassandra.config.Config
 
commitlog_rotation_threshold_in_mb - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync_batch_window_in_ms - Variable in class org.apache.cassandra.config.Config
 
commitlog_sync_period_in_ms - Variable in class org.apache.cassandra.config.Config
 
CommitLogSegment - Class in org.apache.cassandra.db.commitlog
 
CommitLogSegment() - Constructor for class org.apache.cassandra.db.commitlog.CommitLogSegment
 
commitTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
COMPACTED_MARKER - Static variable in class org.apache.cassandra.io.sstable.Component
 
CompactEndpointSerializationHelper - Class in org.apache.cassandra.net
 
CompactEndpointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
compaction_preheat_key_cache - Variable in class org.apache.cassandra.config.Config
 
compaction_thread_priority - Variable in class org.apache.cassandra.config.Config
 
compaction_throughput_mb_per_sec - Variable in class org.apache.cassandra.config.Config
 
CompactionController - Class in org.apache.cassandra.io
Manage compaction options.
CompactionController(ColumnFamilyStore, Collection<SSTableReader>, boolean, int, boolean) - Constructor for class org.apache.cassandra.io.CompactionController
 
CompactionInfo - Class in org.apache.cassandra.io
Implements serializable to allow structured info to be returned via JMX.
CompactionInfo(String, String, CompactionType, long, long) - Constructor for class org.apache.cassandra.io.CompactionInfo
 
CompactionInfo.Holder - Interface in org.apache.cassandra.io
 
CompactionIterator - Class in org.apache.cassandra.io
 
CompactionIterator(CompactionType, Iterable<SSTableReader>, CompactionController) - Constructor for class org.apache.cassandra.io.CompactionIterator
 
CompactionIterator(CompactionType, Iterator, CompactionController) - Constructor for class org.apache.cassandra.io.CompactionIterator
 
CompactionManager - Class in org.apache.cassandra.db
A singleton which manages a private executor of ongoing compactions.
CompactionManager() - Constructor for class org.apache.cassandra.db.CompactionManager
 
CompactionManagerMBean - Interface in org.apache.cassandra.db
 
CompactionType - Enum in org.apache.cassandra.io
 
comparator() - Method in class org.apache.cassandra.cli.CliParser
 
comparator - Variable in class org.apache.cassandra.config.CFMetaData
 
comparator - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
comparator - Static variable in class org.apache.cassandra.db.DecoratedKey
 
comparator() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
comparator_type - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
comparatorType() - Method in class org.apache.cassandra.cql.CqlParser
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
compare(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
compare(Token, Token) - Static method in class org.apache.cassandra.dht.Range
 
compare(File, File) - Method in class org.apache.cassandra.io.util.FileUtils.FileComparator
 
compare(byte[], ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compare(ByteBuffer, byte[]) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
compareEndpoints(InetAddress, InetAddress, InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
compares two endpoints in relation to the target endpoint, returning as Comparator.compare would
compareEndpointStartup(InetAddress, InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
determine which endpoint started up earlier
compareIdTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
compareSubArrays(ByteBuffer, int, ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Compare two ByteBuffer at specified offsets for length.
compareTo(ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
compareTo(DecoratedKey) - Method in class org.apache.cassandra.db.DecoratedKey
 
compareTo(Memtable) - Method in class org.apache.cassandra.db.Memtable
Compares two Memtable based on creation time.
compareTo(Token<BigInteger>) - Method in class org.apache.cassandra.dht.BigIntegerToken
 
compareTo(Token<byte[]>) - Method in class org.apache.cassandra.dht.BytesToken
 
compareTo(Token<ByteBuffer>) - Method in class org.apache.cassandra.dht.LocalToken
 
compareTo(Range) - Method in class org.apache.cassandra.dht.Range
 
compareTo(Token<String>) - Method in class org.apache.cassandra.dht.StringToken
 
compareTo(Token<T>) - Method in class org.apache.cassandra.dht.Token
This determines the comparison for node destination purposes.
compareTo(GossipDigest) - Method in class org.apache.cassandra.gms.GossipDigest
 
compareTo(VersionedValue) - Method in class org.apache.cassandra.gms.VersionedValue
 
compareTo(IndexSummary.KeyPosition) - Method in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
compareTo(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
compareTo(SSTableReader) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
compareTo(NodeId) - Method in class org.apache.cassandra.utils.NodeId
 
compareUnsigned(ByteBuffer, ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
compareUnsigned(byte[], byte[], int, int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
COMPIDENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
compileQuery(String) - Static method in class org.apache.cassandra.cli.CliCompiler
 
complete() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
complete(String) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile.Builder
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
complete(String) - Method in class org.apache.cassandra.io.util.SegmentedFile.Builder
Called after all potential boundaries have been added to apply this Builder to a concrete file on disk.
complete() - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
Registers the newly created tree for rendezvous in Stage.ANTIENTROPY.
completedTaskCount - Variable in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
Component - Class in org.apache.cassandra.io.sstable
SSTables are made up of multiple components in separate files.
Component(Component.Type) - Constructor for class org.apache.cassandra.io.sstable.Component
 
Component(Component.Type, int) - Constructor for class org.apache.cassandra.io.sstable.Component
 
component - Variable in class org.apache.cassandra.streaming.PendingFile
 
COMPONENT_DATA - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPONENT_FILTER - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPONENT_INDEX - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
COMPONENT_STATS - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
components - Variable in class org.apache.cassandra.io.sstable.SSTable
 
components - Variable in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
compose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
COMPRESSION - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
computeNext() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
computeNext() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
computeNext() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
Find the next TreeRange.
computeNext() - Method in class org.apache.cassandra.utils.ReducingIterator
 
computeOldShardMerger(ByteBuffer, List<NodeId.NodeIdRecord>) - Method in class org.apache.cassandra.db.context.CounterContext
Compute a new context such that if applied to context yields the same total but with the older local node id merged into the second to older one (excluding current local node id) if need be.
computeOldShardMerger() - Method in class org.apache.cassandra.db.CounterColumn
 
concatWithIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
concurrent_compactors - Variable in class org.apache.cassandra.config.Config
 
concurrent_reads - Variable in class org.apache.cassandra.config.Config
 
concurrent_replicates - Variable in class org.apache.cassandra.config.Config
 
concurrent_writes - Variable in class org.apache.cassandra.config.Config
 
ConcurrentLinkedHashCache<K,V> - Class in org.apache.cassandra.cache
Wrapper so CLHM can implement ICache interface.
ConcurrentLinkedHashCache(ConcurrentLinkedHashMap<K, V>) - Constructor for class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
ConcurrentLinkedHashCacheProvider - Class in org.apache.cassandra.cache
 
ConcurrentLinkedHashCacheProvider() - Constructor for class org.apache.cassandra.cache.ConcurrentLinkedHashCacheProvider
 
CONDITION - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONDITION - Static variable in class org.apache.cassandra.cli.CliParser
 
condition - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
condition - Variable in class org.apache.cassandra.service.ReadCallback
 
condition - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
CONDITIONS - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONDITIONS - Static variable in class org.apache.cassandra.cli.CliParser
 
CONFIG - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONFIG - Static variable in class org.apache.cassandra.cli.CliParser
 
Config - Class in org.apache.cassandra.config
 
Config() - Constructor for class org.apache.cassandra.config.Config
 
Config.CommitLogSync - Enum in org.apache.cassandra.config
 
Config.DiskAccessMode - Enum in org.apache.cassandra.config
 
Config.RequestSchedulerId - Enum in org.apache.cassandra.config
 
ConfigHelper - Class in org.apache.cassandra.hadoop
 
ConfigHelper() - Constructor for class org.apache.cassandra.hadoop.ConfigHelper
 
configOptions - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
ConfigurationException - Exception in org.apache.cassandra.config
 
ConfigurationException(String) - Constructor for exception org.apache.cassandra.config.ConfigurationException
 
ConfigurationException(String, Exception) - Constructor for exception org.apache.cassandra.config.ConfigurationException
 
confirmReplication(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
CONNECT - Static variable in class org.apache.cassandra.cli.CliLexer
 
connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
Establish a thrift connection to cassandra instance
CONNECT - Static variable in class org.apache.cassandra.cli.CliParser
 
connect(String, Properties) - Method in class org.apache.cassandra.cql.jdbc.CassandraDriver
Method to return connection instance for given connection url and connection props.
connect() - Method in class org.apache.cassandra.security.streaming.SSLFileStreamTask
 
connect() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
connectStatement() - Method in class org.apache.cassandra.cli.CliParser
 
consistency() - Method in class org.apache.cassandra.db.CounterMutation
 
CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONSISTENCYLEVEL - Static variable in class org.apache.cassandra.cli.CliParser
 
consistencyLevel - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
consistencyLevelStatement() - Method in class org.apache.cassandra.cli.CliParser
 
CONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
construct(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Constructs an instance of the given class, which must have a no-arg constructor.
constructStreamHeader(StreamHeader, boolean, int) - Method in class org.apache.cassandra.net.MessagingService
 
contains(Token) - Method in class org.apache.cassandra.dht.AbstractBounds
 
contains(Token) - Method in class org.apache.cassandra.dht.Bounds
 
contains(Token, Token, Token) - Static method in class org.apache.cassandra.dht.Range
 
contains(Range) - Method in class org.apache.cassandra.dht.Range
 
contains(Token) - Method in class org.apache.cassandra.dht.Range
Helps determine if a given point on the DHT ring is contained in the range in question.
containsKey(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
containsKey(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
containsValue(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
contents() - Method in class org.apache.cassandra.db.Memtable
 
Context - Class in org.apache.cassandra.concurrent
Context object adding a collection of key/value pairs into ThreadLocalContext.
Context() - Constructor for class org.apache.cassandra.concurrent.Context
 
context - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
contextManager - Static variable in class org.apache.cassandra.db.CounterColumn
 
controller - Variable in class org.apache.cassandra.io.CompactionIterator
 
CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliLexer
 
CONVERT_TO_TYPE - Static variable in class org.apache.cassandra.cli.CliParser
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
convertFromDiskFormat(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
convertOldStrategyName(String) - Static method in class org.apache.cassandra.config.KSMetaData
 
convertToAvro(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
 
convertToAvro(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
convertToThrift(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
 
convict(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
This method is part of IFailureDetectionEventListener interface.
convict(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
Convict the specified endpoint.
convict(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
convict(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
called from gossiper when it notices a node is not responding.
copy() - Method in class org.apache.cassandra.db.ReadCommand
 
copy() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
copy() - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
copyIntoBytes(byte[], int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
Copy bytes from int into bytes starting from offset.
copyIntoBytes(byte[], int, long) - Static method in class org.apache.cassandra.utils.FBUtilities
Copy bytes from long into bytes starting from offset.
copyTo(CounterContext.ContextState) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
COUNT - Static variable in class org.apache.cassandra.cli.CliLexer
 
COUNT - Static variable in class org.apache.cassandra.cli.CliParser
 
count - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
count - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
COUNTER_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
COUNTER_UPDATE_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
CounterColumn - Class in org.apache.cassandra.db
A column that represents a partitioned counter.
CounterColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumn(ByteBuffer, long, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumn(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterColumn
 
CounterColumnType - Class in org.apache.cassandra.db.marshal
 
CounterContext - Class in org.apache.cassandra.db.context
An implementation of a partitioned counter context.
CounterContext() - Constructor for class org.apache.cassandra.db.context.CounterContext
 
CounterContext.ContextState - Class in org.apache.cassandra.db.context
Helper class to work on contexts (works by iterating over them).
CounterContext.ContextState(ByteBuffer, int) - Constructor for class org.apache.cassandra.db.context.CounterContext.ContextState
 
CounterContext.ContextState(ByteBuffer) - Constructor for class org.apache.cassandra.db.context.CounterContext.ContextState
 
CounterMutation - Class in org.apache.cassandra.db
 
CounterMutation(RowMutation, ConsistencyLevel) - Constructor for class org.apache.cassandra.db.CounterMutation
 
CounterMutationVerbHandler - Class in org.apache.cassandra.db
 
CounterMutationVerbHandler() - Constructor for class org.apache.cassandra.db.CounterMutationVerbHandler
 
CounterUpdateColumn - Class in org.apache.cassandra.db
A counter update while it hasn't been applied yet by the leader replica.
CounterUpdateColumn(ByteBuffer, long, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
 
CounterUpdateColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.CounterUpdateColumn
 
countPendingHints() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
countPendingHints() - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
List all the endpoints that this node has hints for, and count the number of hints for each such endpoint.
countStatement() - Method in class org.apache.cassandra.cli.CliParser
 
CqlLexer - Class in org.apache.cassandra.cql
 
CqlLexer() - Constructor for class org.apache.cassandra.cql.CqlLexer
 
CqlLexer(CharStream) - Constructor for class org.apache.cassandra.cql.CqlLexer
 
CqlLexer(CharStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlLexer
 
CqlParser - Class in org.apache.cassandra.cql
 
CqlParser(TokenStream) - Constructor for class org.apache.cassandra.cql.CqlParser
 
CqlParser(TokenStream, RecognizerSharedState) - Constructor for class org.apache.cassandra.cql.CqlParser
 
CqlParser.comparatorType_return - Class in org.apache.cassandra.cql
 
CqlParser.comparatorType_return() - Constructor for class org.apache.cassandra.cql.CqlParser.comparatorType_return
 
CQLStatement - Class in org.apache.cassandra.cql
 
CQLStatement(StatementType, Object) - Constructor for class org.apache.cassandra.cql.CQLStatement
 
create(int) - Static method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
create(int) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCacheProvider
 
create(int) - Method in interface org.apache.cassandra.cache.IRowCacheProvider
 
create(int) - Method in class org.apache.cassandra.cache.SerializingCacheProvider
 
CREATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
CREATE - Static variable in class org.apache.cassandra.cli.CliParser
 
create(Integer) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(String, String) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamily
 
create(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
 
create(long) - Method in class org.apache.cassandra.db.context.CounterContext
Creates an initial counter context with an initial value for the local node with.
create(NodeId, long, long, boolean) - Method in class org.apache.cassandra.db.context.CounterContext
 
create() - Static method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
create(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Static method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
create(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Static method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
create(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Static method in class org.apache.cassandra.service.WriteResponseHandler
 
create(InetAddress) - Static method in class org.apache.cassandra.service.WriteResponseHandler
 
create(InetAddress, Runnable) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
create(String, InetAddress, Runnable) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(String, InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(String, InetAddress, long, Runnable) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
create(X, Y) - Static method in class org.apache.cassandra.utils.Pair
 
createAllDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Creates all storage-related directories.
createArray(int, Schema) - Static method in class org.apache.cassandra.io.SerDeUtils
Create a generic array of the given type and size.
createAuthenticatedClient(TSocket, Configuration) - Static method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Return a client based on the given socket that points to the configured keyspace, and is logged in with the configured credentials.
createBuilder(Descriptor, OperationType) - Static method in class org.apache.cassandra.io.sstable.SSTableWriter
 
createCfamColumns(CreateColumnFamilyStatement) - Method in class org.apache.cassandra.cql.CqlParser
 
createCfamColumnValidator() - Method in class org.apache.cassandra.cql.CqlParser
 
createCfamKeywordArgument() - Method in class org.apache.cassandra.cql.CqlParser
 
createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
create commutative column
createColumn(ByteBuffer, ByteBuffer, long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
create commutative column
createColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
createColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
CreateColumnFamilyStatement - Class in org.apache.cassandra.cql
A CREATE COLUMNFAMILY parsed from a CQL query statement.
CreateColumnFamilyStatement(String) - Constructor for class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
createColumnFamilyStore(Table, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createColumnFamilyStore(Table, String, IPartitioner, CFMetaData) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
createCompactionWriter(long, String, Collection<SSTableReader>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
createDataInputStream(ByteBuffer) - Static method in class org.apache.cassandra.io.SerDeUtils
 
createDirectory(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createFile(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
createFlushWriter(long, long, ReplayPosition) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
createFrom(Token) - Method in class org.apache.cassandra.dht.AbstractBounds
 
createFrom(Token) - Method in class org.apache.cassandra.dht.Bounds
 
createFrom(Token) - Method in class org.apache.cassandra.dht.Range
 
createHardLink(File, File) - Static method in class org.apache.cassandra.utils.CLibrary
Create a hard link for a given file.
createHardLinkWithExec(File, File) - Static method in class org.apache.cassandra.utils.CLibrary
 
createIndexBuilder(ColumnFamilyStore, SortedSet<ByteBuffer>, ReducingKeyIterator) - Method in class org.apache.cassandra.db.Table
 
createIndexStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
CreateIndexStatement - Class in org.apache.cassandra.cql
A CREATE INDEX statement parsed from a CQL query.
CreateIndexStatement(String, String, Term) - Constructor for class org.apache.cassandra.cql.CreateIndexStatement
 
createKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
CreateKeyspaceStatement - Class in org.apache.cassandra.cql
A CREATE KEYSPACE statement parsed from a CQL query.
CreateKeyspaceStatement(String, Map<String, String>) - Constructor for class org.apache.cassandra.cql.CreateKeyspaceStatement
Creates a new CreateKeyspaceStatement instance for a given keyspace name and keyword arguments.
createLinks(String) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
createRecordReader(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
createReplicationStrategy(KSMetaData) - Method in class org.apache.cassandra.db.Table
 
createReplicationStrategy(String, Class<? extends AbstractReplicationStrategy>, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
createReplicationStrategy(String, String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
CResultSet - Class in org.apache.cassandra.cql.jdbc
 
CURRENT_VERSION - Static variable in class org.apache.cassandra.io.sstable.Descriptor
 
CustomTThreadPoolServer - Class in org.apache.cassandra.thrift
Slightly modified version of the Apache Thrift TThreadPoolServer.
CustomTThreadPoolServer(TThreadPoolServer.Args, ExecutorService) - Constructor for class org.apache.cassandra.thrift.CustomTThreadPoolServer
 

D

D - Static variable in class org.apache.cassandra.cql.CqlLexer
 
D - Static variable in class org.apache.cassandra.cql.CqlParser
 
D_COLDEF_INDEXNAME - Static variable in class org.apache.cassandra.config.ColumnDefinition
 
D_COLDEF_INDEXTYPE - Static variable in class org.apache.cassandra.config.ColumnDefinition
 
DATA - Static variable in class org.apache.cassandra.io.sstable.Component
 
data_file_directories - Variable in class org.apache.cassandra.config.Config
 
DatabaseDescriptor - Class in org.apache.cassandra.config
 
DatabaseDescriptor() - Constructor for class org.apache.cassandra.config.DatabaseDescriptor
 
datacenter(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
DatacenterReadCallback<T> - Class in org.apache.cassandra.service
Datacenter Quorum response handler blocks for a quorum of responses from the local DC
DatacenterReadCallback(IResponseResolver, ConsistencyLevel, IReadCommand, List<InetAddress>) - Constructor for class org.apache.cassandra.service.DatacenterReadCallback
 
DatacenterSyncWriteResponseHandler - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in all datacenters_ (CL.EACH_QUORUM).
DatacenterSyncWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
DatacenterWriteResponseHandler - Class in org.apache.cassandra.service
This class blocks for a quorum of responses _in the local datacenter only_ (CL.LOCAL_QUORUM).
DatacenterWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
DataOutputBuffer - Class in org.apache.cassandra.io.util
An implementation of the DataOutputStream interface.
DataOutputBuffer() - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
DataOutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.DataOutputBuffer
 
dataSize - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
DataTracker - Class in org.apache.cassandra.db
 
DataTracker(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.DataTracker
 
DBConstants - Class in org.apache.cassandra.db
 
DBConstants() - Constructor for class org.apache.cassandra.db.DBConstants
 
deactivate() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
A convenience method to stop and destroy the daemon in one shot.
deactivate() - Method in interface org.apache.cassandra.service.CassandraDaemon
A convenience method to stop and destroy the daemon in one shot.
debug - Variable in class org.apache.cassandra.cli.CliSessionState
 
DebuggableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This class encorporates some Executor best practices for Cassandra.
DebuggableThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DebuggableThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DecimalDigit - Static variable in class org.apache.cassandra.cli.CliLexer
 
DecimalDigit - Static variable in class org.apache.cassandra.cli.CliParser
 
decodeKey(IPartitioner, Descriptor, ByteBuffer) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
Conditionally use the deprecated 'IPartitioner.convertFromDiskFormat' method.
decommission() - Method in class org.apache.cassandra.service.StorageService
 
decommission() - Method in interface org.apache.cassandra.service.StorageServiceMBean
transfer this node's data to other machines and remove it from service.
decommission() - Method in class org.apache.cassandra.tools.NodeProbe
 
decompose(Long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
decompose(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
decompose(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
decompose(BigInteger) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
decompose(UUID) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
decompose(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
decompose(Long) - Method in class org.apache.cassandra.db.marshal.LongType
 
decompose(UUID) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
decompose(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
decompose(UUID) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
decompose(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
decomposes a uuid into raw bytes.
DecoratedKey<T extends Token> - Class in org.apache.cassandra.db
Represents a decorated key, handy for certain operations where just working with strings gets slow.
DecoratedKey(T, ByteBuffer) - Constructor for class org.apache.cassandra.db.DecoratedKey
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
decorateKey(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
Transform key to object representation of the on-disk format.
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
decorateKey(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
decorateTask(Runnable, RunnableScheduledFuture<V>) - Method in class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
DECR - Static variable in class org.apache.cassandra.cli.CliLexer
 
DECR - Static variable in class org.apache.cassandra.cli.CliParser
 
DEFAULT_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
DEFAULT_CONCURENCY_LEVEL - Static variable in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
DEFAULT_GC_GRACE_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_KEY_CACHE_SAVE_PERIOD_IN_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_KEY_CACHE_SIZE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MAX_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MEMTABLE_LIFETIME_IN_MINS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MEMTABLE_OPERATIONS_IN_MILLIONS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MEMTABLE_THROUGHPUT_IN_MB - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MERGE_SHARDS_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_MIN_COMPACTION_THRESHOLD - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_READ_REPAIR_CHANCE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_REPLICATE_ON_WRITE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_ROW_CACHE_PROVIDER - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_ROW_CACHE_SAVE_PERIOD_IN_SECONDS - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_ROW_CACHE_SIZE - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_SYSTEM_MEMTABLE_THROUGHPUT_IN_MB - Static variable in class org.apache.cassandra.config.CFMetaData
 
DEFAULT_THROTTLE_LIMIT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
default_validation_class - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
DEFAULT_WEIGHT - Static variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
default_weight - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
defaultConsistency - Static variable in class org.apache.cassandra.cql.UpdateStatement
 
DefaultDouble - Class in org.apache.cassandra.utils
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
DefaultDouble(double) - Constructor for class org.apache.cassandra.utils.DefaultDouble
 
DefaultInteger - Class in org.apache.cassandra.utils
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
DefaultInteger(int) - Constructor for class org.apache.cassandra.utils.DefaultInteger
 
defaultUser() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
defaultUser() - Method in interface org.apache.cassandra.auth.IAuthenticator
 
defaultUser() - Method in class org.apache.cassandra.auth.SimpleAuthenticator
 
defaultValidator(AbstractType) - Method in class org.apache.cassandra.config.CFMetaData
 
DEFINITION_SCHEMA_COLUMN_NAME - Static variable in class org.apache.cassandra.db.DefsTable
 
DefinitionsAnnounceVerbHandler - Class in org.apache.cassandra.db
 
DefinitionsAnnounceVerbHandler() - Constructor for class org.apache.cassandra.db.DefinitionsAnnounceVerbHandler
 
DefinitionsUpdateResponseVerbHandler - Class in org.apache.cassandra.db
 
DefinitionsUpdateResponseVerbHandler() - Constructor for class org.apache.cassandra.db.DefinitionsUpdateResponseVerbHandler
 
deflate() - Method in class org.apache.cassandra.config.CFMetaData
 
deflate() - Method in class org.apache.cassandra.config.ColumnDefinition
 
deflate() - Method in class org.apache.cassandra.config.KSMetaData
 
defreezeBloomFilter(FileDataInput, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
defreezeBloomFilter(FileDataInput, long, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
De-freeze the bloom filter.
DefsTable - Class in org.apache.cassandra.db
 
DefsTable() - Constructor for class org.apache.cassandra.db.DefsTable
 
DEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
DEL - Static variable in class org.apache.cassandra.cli.CliParser
 
delColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
delete(int, long) - Method in class org.apache.cassandra.db.ColumnFamily
Deprecated. 
delete(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
delete(QueryPath, long) - Method in class org.apache.cassandra.db.RowMutation
 
delete(Descriptor, Set<Component>) - Static method in class org.apache.cassandra.io.sstable.SSTable
We use a ReferenceQueue to manage deleting files that have been compacted and for which no more SSTable references exist.
delete(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
delete(List<String>) - Static method in class org.apache.cassandra.io.util.FileUtils
 
delete(File[]) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteColumnOrSuperColumn(String, Deletion) - Method in class org.apache.cassandra.db.RowMutation
 
DeletedColumn - Class in org.apache.cassandra.db
 
DeletedColumn(ByteBuffer, int, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
 
DeletedColumn(ByteBuffer, ByteBuffer, long) - Constructor for class org.apache.cassandra.db.DeletedColumn
 
deleteHintsForEndpoint(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deleteHintsForEndpoint(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deleteHintsForEndpoint(String) - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
Nuke all hints from this node to `ep`.
deleteOnCleanup() - Method in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
deleteRecursive(File) - Static method in class org.apache.cassandra.io.util.FileUtils
Deletes all files and subdirectories under "dir".
deleteStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
DeleteStatement - Class in org.apache.cassandra.cql
A DELETE parsed from a CQL query statement.
DeleteStatement(List<Term>, String, ConsistencyLevel, List<Term>) - Constructor for class org.apache.cassandra.cql.DeleteStatement
 
deleteWithConfirm(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
deleteWithConfirm(File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
DELETION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
DeletionService - Class in org.apache.cassandra.io
 
DeletionService() - Constructor for class org.apache.cassandra.io.DeletionService
 
DELIMITER - Static variable in class org.apache.cassandra.gms.VersionedValue
 
DELIMITER_STR - Static variable in class org.apache.cassandra.gms.VersionedValue
 
deliverHints(InetAddress) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deliverHints(String) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deliverHints(InetAddress) - Method in class org.apache.cassandra.service.StorageService
Deliver hints to the specified node when it has crashed and come back up/ marked as alive after a network partition
deliverHints(String) - Method in class org.apache.cassandra.service.StorageService
 
deliverHints(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
force hint delivery to an endpoint
delKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
delStatement() - Method in class org.apache.cassandra.cli.CliParser
 
delta() - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
depth - Variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
deque - Variable in class org.apache.cassandra.utils.BoundedStatsDeque
 
desc - Variable in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
desc - Variable in class org.apache.cassandra.streaming.PendingFile
 
DESCRIBE - Static variable in class org.apache.cassandra.cli.CliLexer
 
DESCRIBE - Static variable in class org.apache.cassandra.cli.CliParser
 
describe_cluster_name() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_keyspaces() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_partitioner() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_ring(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_schema_versions() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_snitch() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_splits(String, String, String, int) - Method in class org.apache.cassandra.thrift.CassandraServer
 
describe_version() - Method in class org.apache.cassandra.thrift.CassandraServer
 
describeCluster() - Method in class org.apache.cassandra.cli.CliParser
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
describeOwnership(List<Token>) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate the deltas between tokens in the ring in order to compare relative sizes.
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
describeOwnership(List<Token>) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
describeSchemaVersions() - Static method in class org.apache.cassandra.service.StorageProxy
initiate a request/response session with each live node to check whether or not everybody is using the same migration id.
describeTable() - Method in class org.apache.cassandra.cli.CliParser
 
Descriptor - Class in org.apache.cassandra.io.sstable
A SSTable is described by the keyspace and column family it contains data for, a generation (where higher generations contain more recent data) and an alphabetic version string.
Descriptor(File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
A descriptor that assumes CURRENT_VERSION.
Descriptor(String, File, String, String, int, boolean) - Constructor for class org.apache.cassandra.io.sstable.Descriptor
 
descriptor - Variable in class org.apache.cassandra.io.sstable.SSTable
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput, ColumnFamilyStore, boolean) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput, ColumnFamilyStore, boolean, int) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
deserialize(DataInputStream) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
deserialize(ByteBuffer, int) - Static method in class org.apache.cassandra.db.migration.Migration
 
deserialize(DataInputStream, int, boolean) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
deserialize(DataInput, ColumnFamilyStore, boolean, int) - Method in interface org.apache.cassandra.io.IColumnSerializer
 
deserialize(DataInputStream, int) - Method in interface org.apache.cassandra.io.ICompactSerializer
Deserialize into the specified DataInputStream instance.
deserialize(DataInput) - Method in interface org.apache.cassandra.io.ICompactSerializer2
Deserialize from the specified DataInput instance.
deserialize(Schema, ByteBuffer, T) - Static method in class org.apache.cassandra.io.SerDeUtils
Deserializes a single object based on the given Schema.
deserialize(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
deserialize(DataInputStream) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
deserialize(TDeserializer, TBase, DataInput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
deserialize(DataInputStream, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
deserializeColumns(DataInput, ColumnFamily, boolean, boolean) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromSSTableNoColumns(ColumnFamily, DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeIndex(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Deserialize the index into a structure and return it
deserializeWithSchema(ByteBuffer, T) - Static method in class org.apache.cassandra.io.SerDeUtils
Deserializes a single object as stored along with its Schema by serialize(T).
destroy() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
destroy() - Method in interface org.apache.cassandra.service.CassandraDaemon
Clean up all resources obtained during the lifetime of the daemon.
DestructivePQIterator<T> - Class in org.apache.cassandra.utils
 
DestructivePQIterator(PriorityQueue<T>) - Constructor for class org.apache.cassandra.utils.DestructivePQIterator
 
details_ - Variable in class org.apache.cassandra.net.Header
 
determineBlockFor(ConsistencyLevel, String) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
determineBlockFor(String) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
determineBlockFor(ConsistencyLevel, String) - Method in class org.apache.cassandra.service.ReadCallback
 
determineBlockFor(String) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
dfa1 - Variable in class org.apache.cassandra.cql.CqlParser
 
dfa12 - Variable in class org.apache.cassandra.cql.CqlLexer
 
dfa15 - Variable in class org.apache.cassandra.cli.CliLexer
 
dfa2 - Variable in class org.apache.cassandra.cli.CliParser
 
dfa5 - Variable in class org.apache.cassandra.cql.CqlLexer
 
dfa6 - Variable in class org.apache.cassandra.cli.CliParser
 
diff(IColumn) - Method in class org.apache.cassandra.db.Column
 
diff(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
diff(ColumnFamily, ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
 
diff(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Determine the count relationship between two contexts.
diff(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.db.context.IContext
Determine the relationship between two contexts.
diff(IColumn) - Method in class org.apache.cassandra.db.CounterColumn
 
diff(IColumn) - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
diff(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
diff(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
difference(MerkleTree, MerkleTree) - Static method in class org.apache.cassandra.utils.MerkleTree
 
differences - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
differenceToFetch(Range) - Method in class org.apache.cassandra.dht.Range
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
digest(ColumnFamily) - Static method in class org.apache.cassandra.db.ColumnFamily
 
digest() - Method in class org.apache.cassandra.db.ReadResponse
 
DigestMismatchException - Exception in org.apache.cassandra.service
 
DigestMismatchException(DecoratedKey, ByteBuffer, ByteBuffer) - Constructor for exception org.apache.cassandra.service.DigestMismatchException
 
Digit - Static variable in class org.apache.cassandra.cli.CliLexer
 
Digit - Static variable in class org.apache.cassandra.cli.CliParser
 
DIGIT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
DIGIT - Static variable in class org.apache.cassandra.cql.CqlParser
 
directory - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
disableAutoCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
disableAutoCompaction() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Disable automatic compaction.
disableAutoCompaction() - Method in class org.apache.cassandra.db.CompactionManager
 
discardCompletedSegments(Integer, ReplayPosition) - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
disconnect() - Static method in class org.apache.cassandra.cli.CliMain
Disconnect thrift connection to cassandra instance
disk_access_mode - Variable in class org.apache.cassandra.config.Config
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlLexer
 
displayRecognitionError(String[], RecognitionException) - Method in class org.apache.cassandra.cql.CqlParser
 
DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
DoubleLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.BinaryVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.CounterMutationVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.DefinitionsAnnounceVerbHandler
someone is announcing their schema version.
doVerb(Message, String) - Method in class org.apache.cassandra.db.DefinitionsUpdateResponseVerbHandler
someone sent me their data definitions
doVerb(Message, String) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.ReadVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.RowMutationVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.SchemaCheckVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.db.TruncateVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.dht.BootStrapper.BootstrapTokenVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
doVerb(Message, String) - Method in interface org.apache.cassandra.net.IVerbHandler
This method delivers a message to the implementing class (if the implementing class was registered by a call to MessagingService.registerVerbHandlers).
doVerb(Message, String) - Method in class org.apache.cassandra.net.ResponseVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
Trigger a validation compaction which will return the tree upon completion.
doVerb(Message, String) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.service.IndexScanVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.service.RangeSliceVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.StreamReplyVerbHandler
 
doVerb(Message, String) - Method in class org.apache.cassandra.streaming.StreamRequestVerbHandler
 
drain() - Method in class org.apache.cassandra.service.StorageService
shuts node off to writes, empties memtables and the commit log.
drain() - Method in interface org.apache.cassandra.service.StorageServiceMBean
makes node unavailable for writes, flushes memtables and replays commitlog.
drain() - Method in class org.apache.cassandra.tools.NodeProbe
 
DriverResolverException - Exception in org.apache.cassandra.cql.jdbc
Runtime exception handling in case of runtime error during Driver resolving.
DriverResolverException(String) - Constructor for exception org.apache.cassandra.cql.jdbc.DriverResolverException
Constructor using fields.
DROP - Static variable in class org.apache.cassandra.cli.CliLexer
 
DROP - Static variable in class org.apache.cassandra.cli.CliParser
 
dropCf(Integer) - Method in class org.apache.cassandra.db.Table
 
DropColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
DropColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
DropColumnFamily - Class in org.apache.cassandra.db.migration
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
DropColumnFamily() - Constructor for class org.apache.cassandra.db.migration.DropColumnFamily
Required no-arg constructor
DropColumnFamily(String, String) - Constructor for class org.apache.cassandra.db.migration.DropColumnFamily
 
dropColumnFamilyStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
DropKeyspace - Class in org.apache.cassandra.db.migration.avro
 
DropKeyspace() - Constructor for class org.apache.cassandra.db.migration.avro.DropKeyspace
 
DropKeyspace - Class in org.apache.cassandra.db.migration
 
DropKeyspace() - Constructor for class org.apache.cassandra.db.migration.DropKeyspace
Required no-arg constructor
DropKeyspace(String) - Constructor for class org.apache.cassandra.db.migration.DropKeyspace
 
dropKeyspaceStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
dumpInterArrivalTimes() - Method in class org.apache.cassandra.gms.FailureDetector
Dump the inter arrival times for examination if necessary.
dumpInterArrivalTimes() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
dumpTimings(String) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
dumpTimings(String) - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
dumpToStorage(UUID) - Static method in class org.apache.cassandra.db.DefsTable
dumps current keyspace definitions to storage
duplicate() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
dynamic_snitch - Variable in class org.apache.cassandra.config.Config
 
dynamic_snitch_badness_threshold - Variable in class org.apache.cassandra.config.Config
 
dynamic_snitch_reset_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
dynamic_snitch_update_interval_in_ms - Variable in class org.apache.cassandra.config.Config
 
DynamicEndpointSnitch - Class in org.apache.cassandra.locator
A dynamic snitch that sorts endpoints by latency with an adapted phi failure detector
DynamicEndpointSnitch(IEndpointSnitch) - Constructor for class org.apache.cassandra.locator.DynamicEndpointSnitch
 
DynamicEndpointSnitchMBean - Interface in org.apache.cassandra.locator
 

E

E - Static variable in class org.apache.cassandra.cql.CqlLexer
 
E - Static variable in class org.apache.cassandra.cql.CqlParser
 
ec2region - Variable in class org.apache.cassandra.locator.Ec2Snitch
 
Ec2Snitch - Class in org.apache.cassandra.locator
A snitch that assumes an EC2 region is a DC and an EC2 availability_zone is a rack.
Ec2Snitch() - Constructor for class org.apache.cassandra.locator.Ec2Snitch
 
ec2zone - Variable in class org.apache.cassandra.locator.Ec2Snitch
 
echoData(DataOutput) - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
elementIdx() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
EmbeddedCassandraService - Class in org.apache.cassandra.service
An embedded, in-memory cassandra storage service that listens on the thrift interface as configured in cassandra.yaml This kind of service is useful when running unit tests of services using cassandra for example.
EmbeddedCassandraService() - Constructor for class org.apache.cassandra.service.EmbeddedCassandraService
 
emit(Token) - Method in class org.apache.cassandra.cql.CqlLexer
 
EMPTY_BYTE_BUFFER - Static variable in class org.apache.cassandra.utils.ByteBufferUtil
 
EMPTY_ROW - Static variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
encodedUTF8Length(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
encryption_options - Variable in class org.apache.cassandra.config.Config
 
EncryptionOptions - Class in org.apache.cassandra.config
 
EncryptionOptions() - Constructor for class org.apache.cassandra.config.EncryptionOptions
 
EncryptionOptions.InternodeEncryption - Enum in org.apache.cassandra.config
 
endKey() - Method in class org.apache.cassandra.cli.CliParser
 
endpoint - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
endpoint_snitch - Variable in class org.apache.cassandra.config.Config
 
EndpointSnitchInfo - Class in org.apache.cassandra.locator
 
EndpointSnitchInfo() - Constructor for class org.apache.cassandra.locator.EndpointSnitchInfo
 
EndpointSnitchInfoMBean - Interface in org.apache.cassandra.locator
MBean exposing standard Snitch info
EndpointState - Class in org.apache.cassandra.gms
This abstraction represents both the HeartBeatState and the ApplicationState in an EndpointState instance.
endStmnt() - Method in class org.apache.cassandra.cql.CqlParser
 
ensureCapacity(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Ensure that the long[] is big enough to hold numBits, expanding it if necessary.
ensureCapacityWords(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expand the long[] with the size given as a number of words (64 bit longs).
entrySet() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
entrySet() - Method in class org.apache.cassandra.locator.TokenMetadata
 
enumeratekeys(String, PrintStream) - Static method in class org.apache.cassandra.tools.SSTableExport
Enumerate row keys from an SSTableReader and write the result to a PrintStream.
EOF - Static variable in class org.apache.cassandra.cli.CliLexer
 
EOF - Static variable in class org.apache.cassandra.cli.CliParser
 
EOF - Static variable in class org.apache.cassandra.cql.CqlLexer
 
EOF - Static variable in class org.apache.cassandra.cql.CqlParser
 
EQ - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
equals(Object) - Method in class org.apache.cassandra.config.CFMetaData
 
equals(Object) - Method in class org.apache.cassandra.config.ColumnDefinition
 
equals(Object) - Method in class org.apache.cassandra.config.KSMetaData
 
equals(Object) - Method in class org.apache.cassandra.db.Column
 
equals(Object) - Method in class org.apache.cassandra.db.ColumnFamily
 
equals(Object) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
equals(Object) - Method in class org.apache.cassandra.db.CounterColumn
 
equals(Object) - Method in class org.apache.cassandra.db.DecoratedKey
 
equals(Object) - Method in class org.apache.cassandra.dht.AbstractBounds
 
equals(Object) - Method in class org.apache.cassandra.dht.Bounds
 
equals(Object) - Method in class org.apache.cassandra.dht.BytesToken
 
equals(Object) - Method in class org.apache.cassandra.dht.LocalToken
 
equals(Object) - Method in class org.apache.cassandra.dht.Range
 
equals(Object) - Method in class org.apache.cassandra.dht.Token
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Component
 
equals(Object) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
equals(Object) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
equals(Object) - Method in class org.apache.cassandra.streaming.PendingFile
 
equals(Object) - Method in class org.apache.cassandra.utils.NodeId
 
equals(Object) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
returns true if both sets have the same bits set
equals(Object) - Method in class org.apache.cassandra.utils.Pair
 
err - Variable in class org.apache.cassandra.cli.CliSessionState
 
EscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
EscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
EscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
EscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
escapeSQLString(String) - Static method in class org.apache.cassandra.cli.CliUtils
 
estimatedColumnCount - Variable in class org.apache.cassandra.io.sstable.SSTable
 
EstimatedHistogram - Class in org.apache.cassandra.utils
 
EstimatedHistogram() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(int) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram(long[], long[]) - Constructor for class org.apache.cassandra.utils.EstimatedHistogram
 
EstimatedHistogram.EstimatedHistogramSerializer - Class in org.apache.cassandra.utils
 
EstimatedHistogram.EstimatedHistogramSerializer() - Constructor for class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
estimatedKeys() - Method in class org.apache.cassandra.db.DataTracker
 
estimatedKeys() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
estimatedRowSize - Variable in class org.apache.cassandra.io.sstable.SSTable
 
estimateKeys() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
estimateKeys() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
estimatesRealMemtableSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Executes the given command at some time in the future.
execute() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
execute_cql_query(ByteBuffer, Compression) - Method in class org.apache.cassandra.thrift.CassandraServer
 
executeCLIStatement(String) - Method in class org.apache.cassandra.cli.CliClient
 
executeDelete(String) - Static method in class org.apache.cassandra.io.DeletionService
 
executeQuery() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
executeUpdate() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
executor - Static variable in class org.apache.cassandra.io.DeletionService
 
exhausted - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
EXIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
EXIT - Static variable in class org.apache.cassandra.cli.CliParser
 
exitStatement() - Method in class org.apache.cassandra.cli.CliParser
 
expandingWordNum(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
EXPIRATION_MASK - Static variable in class org.apache.cassandra.db.ColumnSerializer
 
ExpiringColumn - Class in org.apache.cassandra.db
Alternative to Column that have an expiring time.
ExpiringColumn(ByteBuffer, ByteBuffer, long, int) - Constructor for class org.apache.cassandra.db.ExpiringColumn
 
ExpiringColumn(ByteBuffer, ByteBuffer, long, int, int) - Constructor for class org.apache.cassandra.db.ExpiringColumn
 
ExpiringMap<K,V> - Class in org.apache.cassandra.utils
 
ExpiringMap(long) - Constructor for class org.apache.cassandra.utils.ExpiringMap
 
ExpiringMap(long, Function<Pair<K, V>, ?>) - Constructor for class org.apache.cassandra.utils.ExpiringMap
 
export(String, PrintStream, Collection<String>, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export specific rows from an SSTable and write the resulting JSON to a PrintStream.
export(String, PrintStream, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export an SSTable and write the resulting JSON to a PrintStream.
export(String, String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Export an SSTable and write the resulting JSON to standard out.

F

F - Static variable in class org.apache.cassandra.cql.CqlLexer
 
F - Static variable in class org.apache.cassandra.cql.CqlParser
 
FailureDetector - Class in org.apache.cassandra.gms
This FailureDetector is an implementation of the paper titled "The Phi Accrual Failure Detector" by Hayashibara.
FailureDetector() - Constructor for class org.apache.cassandra.gms.FailureDetector
 
FailureDetectorMBean - Interface in org.apache.cassandra.gms
 
FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
fastClear(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit.
fastClear(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
clears a bit.
fastFlip(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit.
fastFlip(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit.
fastGet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
fastGet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
fastSet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets the bit at the specified index.
fastSet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets the bit at the specified index.
FBUtilities - Class in org.apache.cassandra.utils
 
FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
 
fcntl(int, int, long) - Static method in class org.apache.cassandra.utils.CLibrary
 
FILE - Static variable in class org.apache.cassandra.cli.CliLexer
 
FILE - Static variable in class org.apache.cassandra.cli.CliParser
 
file - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
file - Variable in class org.apache.cassandra.streaming.StreamHeader
file being sent on initial stream
FILE_BUFFER_SIZE - Static variable in class org.apache.cassandra.io.CompactionIterator
 
FileDataInput - Interface in org.apache.cassandra.io.util
 
FileMark - Interface in org.apache.cassandra.io.util
 
filename - Variable in class org.apache.cassandra.cli.CliSessionState
 
filenameFor(Component) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
filenameFor(String) - Method in class org.apache.cassandra.io.sstable.Descriptor
 
FileStreamTask - Class in org.apache.cassandra.streaming
 
FileStreamTask(StreamHeader, InetAddress) - Constructor for class org.apache.cassandra.streaming.FileStreamTask
 
FileUtils - Class in org.apache.cassandra.io.util
 
FileUtils() - Constructor for class org.apache.cassandra.io.util.FileUtils
 
FileUtils.FileComparator - Class in org.apache.cassandra.io.util
 
FileUtils.FileComparator() - Constructor for class org.apache.cassandra.io.util.FileUtils.FileComparator
 
filter - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
FILTER - Static variable in class org.apache.cassandra.io.sstable.Component
 
Filter - Class in org.apache.cassandra.utils
 
Filter() - Constructor for class org.apache.cassandra.utils.Filter
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.columniterator.IdentityQueryFilter
 
filterSuperColumn(SuperColumn, int) - Method in interface org.apache.cassandra.db.filter.IFilter
subcolumns of a supercolumn are unindexed, so to pick out parts of those we operate in-memory.
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
finalize() - Method in class org.apache.cassandra.cache.FreeableMemory
avoid re-freeing already-freed memory
finish - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
finish - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
finishBootstrapping() - Method in class org.apache.cassandra.service.StorageService
 
finished(PendingFile, PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
finishedAt - Variable in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
firstKey() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
firstName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
firstToken(ArrayList<Token>, Token) - Static method in class org.apache.cassandra.locator.TokenMetadata
 
firstTokenIndex(ArrayList, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
 
fixMaxId() - Static method in class org.apache.cassandra.config.CFMetaData
 
flip(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit, expanding the set size if necessary
flip(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Flips a range of bits, expanding the set size if necessary
flipAndGet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit and returns the resulting bit value.
flipAndGet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
flips a bit and returns the resulting bit value.
FLOAT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
FLOAT - Static variable in class org.apache.cassandra.cql.CqlParser
 
flush() - Method in class org.apache.cassandra.db.Table
 
flush() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
flush_largest_memtables_at - Variable in class org.apache.cassandra.config.Config
 
flushAndSignal(CountDownLatch, ExecutorService, ExecutorService, ReplayPosition) - Method in class org.apache.cassandra.db.BinaryMemtable
 
flushAndSignal(CountDownLatch, ExecutorService, ExecutorService, ReplayPosition) - Method in interface org.apache.cassandra.db.IFlushable
 
flushAndSignal(CountDownLatch, ExecutorService, ExecutorService, ReplayPosition) - Method in class org.apache.cassandra.db.Memtable
 
flushInProgress - Static variable in class org.apache.cassandra.cache.AutoSavingCache
True if a cache flush is currently executing: only one may execute at a time.
flushLargestMemtables() - Method in class org.apache.cassandra.service.StorageService
Flushes the two largest memtables by ops and by throughput
flushLock - Variable in class org.apache.cassandra.db.ColumnFamilyStore
Lock to allow migrations to block all flushing, so we can be sure not to write orphaned data files
FOLLOW_100_in_helpStatement922 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_100_in_showClusterName2208 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_101_in_helpStatement1469 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_102_in_assumeStatement2123 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_102_in_consistencyLevelStatement2168 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_102_in_getStatement1546 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_103_in_getStatement1590 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_104_in_keyValuePair2755 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_104_in_setStatement1761 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_104_in_setStatement1772 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_arrayConstruct2829 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_columnFamilyExpr2965 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_columnFamilyExpr2982 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_columnFamilyExpr3004 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_109_in_keyRangeExpr3073 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_110_in_arrayConstruct2834 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_110_in_hashConstruct2882 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_arrayConstruct2839 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_columnFamilyExpr2969 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_columnFamilyExpr2988 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_columnFamilyExpr3010 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_111_in_keyRangeExpr3088 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_112_in_hashConstruct2877 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_113_in_hashConstruct2888 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_114_in_hashElementPair2926 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_114_in_keyRangeExpr3080 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_115_in_functionCall3381 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_116_in_functionCall3386 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_117_in_host_name3554 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_75_in_createColumnFamilyStatement1404 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_75_in_createIndexStatement1670 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_75_in_deleteStatement1145 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_75_in_insertStatement679 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_75_in_insertStatement722 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_75_in_selectStatement303 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_76_in_createColumnFamilyStatement1419 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_76_in_createIndexStatement1676 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_76_in_deleteStatement1153 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_76_in_insertStatement700 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_76_in_insertStatement740 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_76_in_selectStatement309 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_77_in_createColumnFamilyStatement1411 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_77_in_insertStatement688 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_77_in_insertStatement730 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_77_in_selectExpression522 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_77_in_termList1910 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_77_in_updateStatement962 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_78_in_selectExpression560 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_79_in_batchUpdateStatement839 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_79_in_batchUpdateStatement850 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_79_in_endStmnt2079 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_80_in_createColumnFamilyStatement1438 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_80_in_createColumnFamilyStatement1464 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_80_in_createKeyspaceStatement1260 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_80_in_createKeyspaceStatement1306 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_80_in_deleteStatement1103 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_80_in_termPair1943 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_80_in_updateStatement983 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_98_in_connectStatement629 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_98_in_connectStatement675 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_99_in_describeCluster2587 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_99_in_helpStatement840 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_addColumnFamily_in_statement476 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_addKeyspace_in_statement468 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_AND_in_getStatement1595 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_AND_in_keyValuePairExpr2688 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_API_VERSION_in_helpStatement979 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_API_VERSION_in_showVersion2473 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_arrayConstruct_in_attrValue2786 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ASSUME_in_assumeStatement2115 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ASSUME_in_helpStatement1396 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_assumeStatement_in_statement588 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attr_name_in_keyValuePair2753 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValue_in_keyValuePair2757 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueDouble_in_attrValue2810 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueInt_in_attrValue2802 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_attrValueString_in_attrValue2794 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_batchUpdateStatement_in_query105 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_BY_in_incrStatement1827 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_BY_in_incrStatement1870 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_addColumnFamily2279 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_delColumnFamily2433 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_helpStatement1064 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_helpStatement1095 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_helpStatement1154 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COLUMN_in_updateColumnFamily2356 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_assumeStatement2117 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_columnFamilyExpr2963 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_delColumnFamily2437 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_getStatement1588 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_listStatement2024 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamily_in_truncateStatement2082 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_countStatement1919 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_delStatement1955 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_getStatement1543 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_incrStatement1824 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_incrStatement1867 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnFamilyExpr_in_setStatement1759 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_columnFamilyExpr2986 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_columnFamilyExpr3008 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_columnOrSuperColumn_in_getCondition1657 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_comparatorType_in_createCfamColumnValidator1555 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_comparatorType_in_createCfamKeywordArgument1588 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_CONNECT_in_connectStatement625 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONNECT_in_connectStatement671 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONNECT_in_helpStatement755 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_connectStatement_in_statement428 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONSISTENCYLEVEL_in_consistencyLevelStatement2166 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CONSISTENCYLEVEL_in_helpStatement1422 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_consistencyLevelStatement_in_statement596 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COUNT_in_countStatement1917 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_COUNT_in_helpStatement1316 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_countStatement_in_statement444 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_addColumnFamily2277 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_addKeyspace2239 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_helpStatement1005 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_CREATE_in_helpStatement1062 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_createCfamColumns_in_createColumnFamilyStatement1406 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamColumns_in_createColumnFamilyStatement1413 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamColumnValidator_in_createCfamColumns1514 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamColumnValidator_in_createCfamColumns1528 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamKeywordArgument_in_createColumnFamilyStatement1442 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createCfamKeywordArgument_in_createColumnFamilyStatement1468 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createColumnFamilyStatement_in_query162 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createIndexStatement_in_query172 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_createKeyspaceStatement_in_query152 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_DECR_in_helpStatement1263 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DECR_in_incrStatement1865 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DEL_in_delStatement1953 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DEL_in_helpStatement1289 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_delColumnFamily_in_statement500 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_deleteStatement_in_query140 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_delKeyspace_in_statement508 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_delStatement_in_statement524 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_describeCluster2585 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_describeTable2538 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_helpStatement809 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DESCRIBE_in_helpStatement838 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_describeCluster_in_statement460 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_describeTable_in_statement452 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DoubleLiteral_in_attrValueDouble3182 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_delColumnFamily2431 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_delKeyspace2393 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1123 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_DROP_in_helpStatement1152 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_dropColumnFamilyStatement_in_query192 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_dropKeyspaceStatement_in_query182 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endKey_in_keyRangeExpr3082 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_endStmnt_in_createColumnFamilyStatement1490 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_createIndexStatement1678 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_createKeyspaceStatement1339 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_deleteStatement1176 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_dropColumnFamilyStatement1774 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_dropKeyspaceStatement1729 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_insertStatement769 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_query95 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_selectStatement428 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_truncateStatement2062 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_endStmnt_in_useStatement222 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_EOF_in_batchUpdateStatement868 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_EOF_in_endStmnt2083 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_EOF_in_root412 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_EXIT_in_exitStatement1518 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_EXIT_in_helpStatement866 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_exitStatement_in_statement436 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_addColumnFamily2281 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_delColumnFamily2435 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_helpStatement1066 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_helpStatement1097 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_helpStatement1156 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_FAMILY_in_updateColumnFamily2358 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionArgument_in_functionCall3383 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_columnOrSuperColumn3508 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_rowKey3328 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_functionCall_in_value3361 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_getStatement1541 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_getStatement1586 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_GET_in_helpStatement1183 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getCondition_in_getStatement1592 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getCondition_in_getStatement1597 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_getStatement_in_statement532 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashConstruct_in_arrayConstruct2832 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashElementPair_in_hashConstruct2879 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_hashElementPair_in_hashConstruct2884 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1003 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1032 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1060 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1091 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1121 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1150 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1181 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1208 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1235 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1261 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1287 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1314 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1341 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1368 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1394 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1420 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement1446 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement726 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement728 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement753 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement780 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement807 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement836 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement864 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement891 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement918 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement946 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_HELP_in_helpStatement975 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_helpStatement_in_statement540 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_host_in_connectStatement627 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_host_name_in_host3524 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IDENT_in_createColumnFamilyStatement1436 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_IDENT_in_createColumnFamilyStatement1462 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_IDENT_in_createIndexStatement1648 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_IDENT_in_term1870 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_IDENT_in_useStatement218 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_Identifier_in_assumeStatement2121 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_assumeStatement2127 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_attr_name3131 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_columnFamily3295 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_columnName3120 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_columnOrSuperColumn3492 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_command3255 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_consistencyLevelStatement2172 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_functionCall3379 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_host_name3551 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_host_name3556 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_keyspace3206 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_keyspaceNewName3228 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_newColumnFamily3266 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_objectName3195 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_rowKey3312 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_username3275 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_Identifier_in_value3345 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INCR_in_helpStatement1237 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_INCR_in_incrStatement1822 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrementValue_in_incrStatement1831 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrementValue_in_incrStatement1874 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_incrStatement_in_statement556 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_insertStatement_in_query81 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_selectExpression473 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_selectStatement411 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_INTEGER_in_term1858 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_IntegerNegativeLiteral_in_columnOrSuperColumn3500 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_rowKey3324 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerNegativeLiteral_in_value3353 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_columnOrSuperColumn3496 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_getStatement1606 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_listStatement2034 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_port3600 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_rowKey3320 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_setStatement1776 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IntegerPositiveLiteral_in_value3349 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_ip_address_in_connectStatement673 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_IP_ADDRESS_in_ip_address3570 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_K_AND_in_createColumnFamilyStatement1458 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_createKeyspaceStatement1292 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_AND_in_whereClause610 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_APPLY_in_batchUpdateStatement864 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_BATCH_in_batchUpdateStatement810 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_BATCH_in_batchUpdateStatement866 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_BEGIN_in_batchUpdateStatement808 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_createColumnFamilyStatement1376 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COLUMNFAMILY_in_dropColumnFamilyStatement1756 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CONSISTENCY_in_batchUpdateStatement816 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CONSISTENCY_in_deleteStatement1080 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CONSISTENCY_in_insertStatement754 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CONSISTENCY_in_selectStatement367 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CONSISTENCY_in_updateStatement938 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_COUNT_in_selectStatement301 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CREATE_in_createColumnFamilyStatement1374 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CREATE_in_createIndexStatement1641 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_CREATE_in_createKeyspaceStatement1215 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DELETE_in_deleteStatement1026 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DROP_in_dropColumnFamilyStatement1754 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_DROP_in_dropKeyspaceStatement1709 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FIRST_in_selectExpression469 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FROM_in_deleteStatement1058 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_FROM_in_selectStatement335 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_IN_in_deleteStatement1143 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INDEX_in_createIndexStatement1643 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INSERT_in_insertStatement649 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_INTO_in_insertStatement651 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_createCfamColumns1524 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_createCfamColumns1532 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_deleteStatement1101 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_deleteStatement1141 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_insertStatement681 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_term1846 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEY_in_updateStatement981 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEYSPACE_in_createKeyspaceStatement1217 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_KEYSPACE_in_dropKeyspaceStatement1711 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_batchUpdateStatement818 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_deleteStatement1082 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_insertStatement756 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_selectStatement369 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LEVEL_in_updateStatement940 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_LIMIT_in_selectStatement407 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_ON_in_createIndexStatement1652 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_PRIMARY_in_createCfamColumns1530 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_REVERSED_in_selectExpression488 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_SELECT_in_selectStatement253 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_SET_in_updateStatement956 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_TRUNCATE_in_truncateStatement2042 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_UPDATE_in_updateStatement907 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USE_in_useStatement216 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USING_in_batchUpdateStatement814 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USING_in_deleteStatement1078 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USING_in_insertStatement752 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USING_in_selectStatement365 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_USING_in_updateStatement936 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_VALUES_in_insertStatement710 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WHERE_in_deleteStatement1097 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WHERE_in_selectStatement388 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WHERE_in_updateStatement979 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WITH_in_createColumnFamilyStatement1432 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_K_WITH_in_createKeyspaceStatement1245 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_keyRangeExpr_in_listStatement2026 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_addKeyspace2241 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_delKeyspace2395 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_delKeyspace2397 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_describeTable2540 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_describeTable2543 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1007 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1036 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement1125 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_helpStatement811 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACE_in_updateKeyspace2319 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyspace_in_useKeyspace2620 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACES_in_helpStatement950 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_KEYSPACES_in_showKeyspaces2506 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePair_in_keyValuePairExpr2695 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_addColumnFamily2283 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_addKeyspace2243 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_updateColumnFamily2360 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_keyValuePairExpr_in_updateKeyspace2321 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_getStatement1602 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIMIT_in_listStatement2030 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIST_in_helpStatement1343 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_LIST_in_listStatement2022 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_listStatement_in_statement572 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_objectName_in_keyValuePairExpr2683 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_operator_in_getCondition1659 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_password_in_connectStatement636 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_password_in_connectStatement682 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_password_in_useKeyspace2631 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_port_in_connectStatement631 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_port_in_connectStatement677 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUIT_in_exitStatement1504 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_QUIT_in_helpStatement893 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_RANGEOP_in_selectExpression544 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_relation_in_whereClause594 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_relation_in_whereClause614 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_rowKey_in_columnFamilyExpr2967 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_rowKey_in_hashElementPair2924 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_selectExpression_in_selectStatement269 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_selectExpression_in_selectStatement307 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_selectStatement_in_query69 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_SEMICOLON_in_root409 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_attrValueInt0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_attrValueString3142 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_comparatorType0 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createCfamKeywordArgument1600 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createColumnFamilyStatement1380 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createIndexStatement1656 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1221 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1250 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1264 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1296 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_createKeyspaceStatement1310 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_deleteStatement1062 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_dropColumnFamilyStatement1760 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_dropKeyspaceStatement1715 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_endKey3474 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_functionArgument0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SET_in_helpStatement1210 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_incrementValue0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_insertStatement655 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_operator0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_relation1990 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_selectStatement339 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_SET_in_setStatement1757 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_startKey3453 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_truncateStatement2046 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_set_in_typeIdentifier0 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_set_in_updateStatement911 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_setStatement_in_statement548 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement920 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement948 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_helpStatement977 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showClusterName2206 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showKeyspaces2504 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_SHOW_in_showVersion2471 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showClusterName_in_showStatement1989 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showKeyspaces_in_showStatement2005 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showStatement_in_statement564 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_showVersion_in_showStatement1997 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_startKey_in_keyRangeExpr3077 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_statement_in_root407 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_STRING_LITERAL_in_createCfamColumnValidator1565 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_STRING_LITERAL_in_term1852 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_StringLiteral_in_columnOrSuperColumn3504 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_comparator3239 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_password3284 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_replica_placement_strategy3217 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_rowKey3316 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_StringLiteral_in_value3357 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_term_in_createCfamColumns1510 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_createIndexStatement1674 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_deleteStatement1107 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_insertStatement692 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_insertStatement726 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_insertStatement734 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_relation1982 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_relation2012 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_selectExpression505 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_selectExpression526 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_selectExpression542 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_selectExpression548 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termList1905 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termList1914 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPair1941 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_termPair1947 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_term_in_updateStatement987 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termList_in_deleteStatement1042 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termList_in_deleteStatement1149 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termPair_in_updateStatement958 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_termPair_in_updateStatement964 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_TRUNCATE_in_helpStatement1370 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TRUNCATE_in_truncateStatement2080 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_truncateStatement_in_query130 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_truncateStatement_in_statement580 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_TTL_in_setStatement1770 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_typeIdentifier_in_getStatement1548 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_helpStatement1034 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_helpStatement1093 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_updateColumnFamily2354 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_UPDATE_in_updateKeyspace2317 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateColumnFamily_in_statement492 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateKeyspace_in_statement484 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_updateStatement_in_batchUpdateStatement837 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_updateStatement_in_batchUpdateStatement848 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_updateStatement_in_query93 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_USE_in_helpStatement782 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_USE_in_useKeyspace2618 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_useKeyspace_in_statement516 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_connectStatement634 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_connectStatement680 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_username_in_useKeyspace2624 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_useStatement_in_query115 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_UUID_in_term1864 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_value_in_getCondition1661 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_value_in_hashElementPair2928 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_value_in_setStatement1765 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_whereClause_in_selectStatement390 - Static variable in class org.apache.cassandra.cql.CqlParser
 
FOLLOW_WITH_in_keyValuePairExpr2692 - Static variable in class org.apache.cassandra.cli.CliParser
 
FOLLOW_WITH_in_setStatement1768 - Static variable in class org.apache.cassandra.cli.CliParser
 
forceBlockingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceCleanup(NodeId.OneShotRenewer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceCleanup(NodeId.OneShotRenewer) - Method in class org.apache.cassandra.db.Table
Do a cleanup of keys that do not belong locally.
forceFilterFailures() - Method in class org.apache.cassandra.io.sstable.SSTableReader
For testing purposes only.
forceFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceFlush() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Triggers an immediate memtable flush.
forceFlushBinary() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceFlushIfExpired() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
forceMajorCompaction() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
force a major compaction of this column family
forceRemoveCompletion() - Method in class org.apache.cassandra.service.StorageService
Force a remove operation to complete.
forceRemoveCompletion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Force a remove operation to finish.
forceRemoveCompletion() - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableCleanup(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableCleanup(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Trigger a cleanup of keys on a single keyspace
forceTableCleanup(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableCompaction(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableCompaction(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Forces major compaction of a single keyspace
forceTableCompaction(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableFlush(String, String...) - Method in class org.apache.cassandra.service.StorageService
Flush all memtables for a table and column families.
forceTableFlush(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Flush all memtables for the given column families, or all columnfamilies for the given table if none are explicitly listed.
forceTableFlush(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceTableRepair(String, String...) - Method in class org.apache.cassandra.service.StorageService
Trigger proactive repair for a table and column families.
forceTableRepair(Range, String, String...) - Method in class org.apache.cassandra.service.StorageService
 
forceTableRepair(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Triggers proactive repair for given column families, or all columnfamilies for the given table if none are explicitly listed.
forceTableRepair(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
forceUserDefinedCompaction(String, String) - Method in class org.apache.cassandra.db.CompactionManager
 
forceUserDefinedCompaction(String, String) - Method in interface org.apache.cassandra.db.CompactionManagerMBean
Triggers the compaction of user specified sstables.
forProgress(long, long) - Method in class org.apache.cassandra.io.CompactionInfo
 
FORWARD_HEADER - Static variable in class org.apache.cassandra.db.RowMutation
 
forwardsCompatibleOptions(KsDef) - Static method in class org.apache.cassandra.config.KSMetaData
 
framed - Variable in class org.apache.cassandra.cli.CliSessionState
 
free() - Method in class org.apache.cassandra.cache.FreeableMemory
 
FreeableMemory - Class in org.apache.cassandra.cache
 
FreeableMemory(long) - Constructor for class org.apache.cassandra.cache.FreeableMemory
 
fromByteArray(ByteBuffer) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromColumnDef(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromColumnDef(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromColumnDef(List<ColumnDef>) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Component
Filename of the form "/-[tmp-][-]-", where is of the form "[-]".
fromFilename(String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
 
fromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.Descriptor
Filename of the form "/-[tmp-][-]-"
fromInt(int) - Static method in class org.apache.cassandra.utils.NodeId
Function for test purposes, do not use otherwise.
fromRemote - Variable in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a byte representation of the given string.
fromString(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.BytesType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.LongType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
fromString(String) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromThrift(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
fromThrift(KsDef, CFMetaData...) - Static method in class org.apache.cassandra.config.KSMetaData
 
fullRange - Variable in class org.apache.cassandra.utils.MerkleTree
The top level range that this MerkleTree covers.
FULLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliLexer
 
FUNCTION_CALL - Static variable in class org.apache.cassandra.cli.CliParser
 
functionArgument() - Method in class org.apache.cassandra.cli.CliParser
 
functionCall() - Method in class org.apache.cassandra.cli.CliParser
 

G

G - Static variable in class org.apache.cassandra.cql.CqlLexer
 
G - Static variable in class org.apache.cassandra.cql.CqlParser
 
gc_grace_seconds - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
gcBefore() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
gcBefore - Variable in class org.apache.cassandra.io.CompactionController
 
gcGraceSeconds(int) - Method in class org.apache.cassandra.config.CFMetaData
 
GCInspector - Class in org.apache.cassandra.service
 
GCInspector() - Constructor for class org.apache.cassandra.service.GCInspector
 
GE - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
generate() - Static method in class org.apache.cassandra.utils.NodeId
 
generation - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
get(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
get(K) - Method in interface org.apache.cassandra.cache.ICache
 
get(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
get(Object) - Method in class org.apache.cassandra.cache.SerializingCache
 
GET - Static variable in class org.apache.cassandra.cli.CliLexer
 
GET - Static variable in class org.apache.cassandra.cli.CliParser
 
get(Object) - Method in class org.apache.cassandra.concurrent.Context
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.CfDef
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.ColumnDef
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.KsDef
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.Migration
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.RenameKeyspace
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
get(int) - Method in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
get(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
get(long, TimeUnit) - Method in interface org.apache.cassandra.net.IAsyncResult
Same operation as the above get() but allows the calling thread to specify a timeout.
get() - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
get() - Method in interface org.apache.cassandra.service.IWriteResponseHandler
 
get() - Method in class org.apache.cassandra.service.ReadCallback
 
get() - Method in class org.apache.cassandra.service.RepairCallback
 
get() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
get(InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamInSession
 
get(InetAddress, long) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
get(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
get(Token) - Method in class org.apache.cassandra.utils.MerkleTree
For testing purposes.
get(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index.
get(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true or false for the specified bit index
get_count(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_indexed_slices(ColumnParent, IndexClause, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_range_slices(ColumnParent, SlicePredicate, KeyRange, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
get_slice(ByteBuffer, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
getActiveCompactions() - Method in class org.apache.cassandra.db.CompactionManager
 
getActiveCount() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Get the current number of running tasks
getActiveCount() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
Get the current number of running tasks
getAddressRanges(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAddressRanges() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getAdjustedCacheSize(long) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getAdjustedTimestamp(UUID) - Static method in class org.apache.cassandra.utils.UUIDGen
Returns a milliseconds-since-epoch value for a type-1 UUID.
getAge(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
getAllDataFileLocations() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAllDataFileLocationsForTable(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Get a list of data directories for a given table
getAllEndpointStates() - Method in class org.apache.cassandra.gms.FailureDetector
 
getAllEndpointStates() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getAllRanges(List<Token>) - Method in class org.apache.cassandra.service.StorageService
Get all ranges that span the ring given a set of tokens.
getAllSSTables() - Method in class org.apache.cassandra.db.Table
 
getAndSet(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets a bit and returns the previous value.
getAndSet(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets a bit and returns the previous value.
getApplicationState(ApplicationState) - Method in class org.apache.cassandra.gms.EndpointState
 
getApplicationStateMap() - Method in class org.apache.cassandra.gms.EndpointState
Deprecated. 
getApproximateKeyCount(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
getArray(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
You should almost never use this.
getAttributeValue(Node, String) - Static method in class org.apache.cassandra.utils.XMLUtils
 
getAuthenticator() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getAuthority() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBadnessThreshold() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getBadnessThreshold() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getBalancedToken(TokenMetadata, Map<InetAddress, Double>) - Static method in class org.apache.cassandra.dht.BootStrapper
 
getBasicController(boolean) - Static method in class org.apache.cassandra.io.CompactionController
Returns a controller that never purge
getBigInteger(int) - Method in interface org.apache.cassandra.cql.jdbc.CassandraResultSet
 
getBigInteger(String) - Method in interface org.apache.cassandra.cql.jdbc.CassandraResultSet
 
getBigInteger(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getBigInteger(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getBit(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
returns 1 if the bit is set, 0 if not.
getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
 
getBits() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: returns the long[] storing the bits
getBitSet() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getBloomFilter() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.DataTracker
 
getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.DataTracker
 
getBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getBMTThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBoolean(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getBoolean(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getBootstrapToken(TokenMetadata, Map<InetAddress, Double>) - Static method in class org.apache.cassandra.dht.BootStrapper
if initialtoken was specified, use that.
getBootstrapToken() - Method in class org.apache.cassandra.service.StorageService
return a token to which if a node bootstraps it will get about 1/2 of this node's range
getBootstrapTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
caller should not modify bootstrapTokens
getBucketOffsets() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getBuckets(boolean) - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
getBuilder(Config.DiskAccessMode) - Static method in class org.apache.cassandra.io.util.SegmentedFile
 
getBuiltIndexes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Returns a list of the names of the built column indexes for current store
getBuiltIndexes() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns a list of the names of the built column indexes for current store
getByteBuffer(AbstractType<?>) - Method in class org.apache.cassandra.cql.Term
Returns the typed value, serialized to a ByteBuffer according to a comparator/validator.
getByteBuffer() - Method in class org.apache.cassandra.cql.Term
Returns the typed value, serialized to a ByteBuffer.
getBytes(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getBytes(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getBytesComplete() - Method in class org.apache.cassandra.io.CompactionInfo
 
getBytesRead() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getBytesRead() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getCachedEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getCachedPosition(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getCachePath() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getCapacity() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getCapacity() - Method in interface org.apache.cassandra.cache.InstrumentingCacheMBean
 
getCF(Integer) - Static method in class org.apache.cassandra.config.CFMetaData
 
getCFMetaData(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCFMetaData(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCFMetaData(Descriptor) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCFMetaData(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Returns a CFMetaData instance based on the parameters parsed from this CREATE statement, or defaults where applicable.
getCfNamesByKeySpace(KsDef) - Static method in class org.apache.cassandra.cli.CliUtils
Returns set of column family names in specified keySpace.
getCfsProxy(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getClass(String) - Static method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getClock() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCollatingIterator(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.CompactionIterator
 
getCollatingIterator() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getColumn(Tree, int) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumn(int) - Method in interface org.apache.cassandra.cql.jdbc.CassandraResultSet
 
getColumn(String) - Method in interface org.apache.cassandra.cql.jdbc.CassandraResultSet
 
getColumn(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getColumn(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getColumn(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumn_metadata() - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnComparator(AbstractType) - Method in interface org.apache.cassandra.db.filter.IFilter
 
getColumnComparator(AbstractType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getColumnComparator(AbstractType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getColumnComparator() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getColumnCount() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnDefinition(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getColumnFamilies() - Method in class org.apache.cassandra.db.RowMutation
 
getColumnFamily(Tree, List<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily(String, List<CfDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily() - Method in class org.apache.cassandra.cql.CreateIndexStatement
Column family namespace.
getColumnFamily() - Method in class org.apache.cassandra.cql.DeleteStatement
 
getColumnFamily() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnFamily() - Method in class org.apache.cassandra.cql.UpdateStatement
 
getColumnFamily(DecoratedKey, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamily(QueryFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
get a list of columns starting from a given column, in a specified order.
getColumnFamily() - Method in interface org.apache.cassandra.db.columniterator.IColumnIterator
 
getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
getColumnFamily() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
getColumnFamily(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
 
getColumnFamily() - Method in class org.apache.cassandra.io.CompactionController
 
getColumnFamily() - Method in class org.apache.cassandra.io.CompactionInfo
 
getColumnFamily() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getColumnFamilyName() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamilyName() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getColumnFamilyName() - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getColumnFamilyName() - Method in class org.apache.cassandra.db.ReadCommand
 
getColumnFamilyName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyStore(Integer) - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyStoreMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getColumnFamilyStores() - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyType(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnFamilyWithColumns() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getColumnFinish() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
Column name to index.
getColumnNames() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnNames() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnRelations() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnRelations() - Method in class org.apache.cassandra.cql.WhereClause
 
getColumns() - Method in class org.apache.cassandra.cql.DeleteStatement
 
getColumns() - Method in class org.apache.cassandra.cql.SelectExpression
 
getColumns() - Method in class org.apache.cassandra.cql.UpdateStatement
 
getColumnSerializer() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnSerializer() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectExpression
 
getColumnsLimit() - Method in class org.apache.cassandra.cql.SelectStatement
 
getColumnsMap() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnsString(Collection<IColumn>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getColumnStart() - Method in class org.apache.cassandra.cql.SelectStatement
 
getCommandCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getCommandCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for Command(Mutations, Read etc) TCP Connections
getCommandPendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getCommandPendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for Command(Mutations, Read etc) TCP Connections
getComment() - Method in class org.apache.cassandra.config.CFMetaData
 
getCommitLogLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSegmentSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSync() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSyncBatchWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCommitLogSyncPeriod() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCompactedRow() - Method in class org.apache.cassandra.io.CompactionIterator
 
getCompactionInfo() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
getCompactionInfo() - Method in class org.apache.cassandra.db.Table.IndexBuilder
 
getCompactionInfo() - Method in interface org.apache.cassandra.io.CompactionInfo.Holder
 
getCompactionInfo() - Method in class org.apache.cassandra.io.CompactionIterator
 
getCompactionInfo() - Method in class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
getCompactionLock() - Method in class org.apache.cassandra.db.CompactionManager
 
getCompactionManagerProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCompactions() - Method in class org.apache.cassandra.db.CompactionManager
 
getCompactions() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
List of running compaction objects.
getCompactionSummary() - Method in class org.apache.cassandra.db.CompactionManager
 
getCompactionSummary() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
List of running compaction summary strings.
getCompactionThreadPriority() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCompactionThreshold(PrintStream, String, String) - Method in class org.apache.cassandra.tools.NodeProbe
Get the compaction threshold
getCompactionThroughputMbPerSec() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getComparator(CharSequence) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getComparator(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getComparator(String) - Method in class org.apache.cassandra.cql.SelectStatement
 
getComparator(String) - Method in class org.apache.cassandra.cql.UpdateStatement
 
getComparator() - Method in class org.apache.cassandra.db.ColumnFamily
 
getComparator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getComparator() - Method in interface org.apache.cassandra.db.IColumnContainer
 
getComparator() - Method in class org.apache.cassandra.db.ReadCommand
 
getComparator() - Method in class org.apache.cassandra.db.SuperColumn
 
getComparator() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
getComparator(AbstractType, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
 
getComparator() - Method in interface org.apache.cassandra.io.util.IIterableColumns
 
getComparator(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
getComparatorFor(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getComparatorFor(String, String, ByteBuffer) - Static method in class org.apache.cassandra.db.ColumnFamily
 
getCompletedMesssages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getCompletedTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Get the number of completed tasks
getCompletedTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Get the number of completed tasks
getCompletedTasks() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
Get the number of completed tasks
getCompletedTasks() - Method in class org.apache.cassandra.db.CompactionManager
 
getCompletedTasks() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getConcurrentCompactors() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentReplicators() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCondition() - Method in class org.apache.cassandra.cli.CliParser
 
getConfiguredCacheSize(CFMetaData) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getConfiguredCacheSize(CFMetaData) - Method in class org.apache.cassandra.cache.AutoSavingKeyCache
 
getConfiguredCacheSize(CFMetaData) - Method in class org.apache.cassandra.cache.AutoSavingRowCache
 
getConnection(InetAddress, Message) - Method in class org.apache.cassandra.net.MessagingService
 
getConnectionPool(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.BatchUpdateStatement
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.DeleteStatement
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.SelectStatement
 
getConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
Returns the consistency level of this UPDATE statement, either one parsed from the CQL statement, or the default level otherwise.
getConsistencyThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
getContext() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getContextMapping(PendingFile) - Static method in class org.apache.cassandra.streaming.StreamIn
Translates remote files to local files by creating a local sstable per remote sstable.
getCorePoolSize() - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
getCount() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getCurrentGenerationNumber(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getCurrentGenerationNumber() - Method in class org.apache.cassandra.service.StorageService
 
getCurrentGenerationNumber() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Return the generation value for this node.
getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
 
getCurrentKey() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getCurrentLocalNodeId() - Static method in class org.apache.cassandra.db.SystemTable
Read the current local node id from the system table or null if no such node id is recorded.
getCurrentValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getData() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
Returns the current contents of the buffer.
getData() - Method in class org.apache.cassandra.io.util.OutputBuffer
 
getData() - Method in interface org.apache.cassandra.service.IResponseResolver
returns the data response without comparing with any digests
getData() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getData() - Method in class org.apache.cassandra.service.RowDigestResolver
 
getData() - Method in class org.apache.cassandra.service.RowRepairResolver
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
getDatacenter(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getDatacenter(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Datacenter name depending on the respective snitch used, given the hostname/ip
getDatacenter(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String representing the datacenter this endpoint belongs to
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Return the data center for which an endpoint resides in
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
 
getDatacenter(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getDatacenters() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getDataFileLocation(long) - Method in class org.apache.cassandra.db.Table
 
getDataFileLocationForTable(String, long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDate(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getDate(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getDate(int, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getDate(String, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getDefaultValidator() - Method in class org.apache.cassandra.config.CFMetaData
 
getDefsVersion() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDestinations() - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
getDirectScanner(int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Direct I/O SSTableScanner
getDirectScanner(int, Range) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Direct I/O SSTableScanner over a defined range of tokens.
getDiskAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDouble(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getDouble(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getDrainProgress() - Method in class org.apache.cassandra.service.StorageService
 
getDrainProgress() - Method in interface org.apache.cassandra.service.StorageServiceMBean
get the progress of a drain operation
getDynamicBadnessThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicResetInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDynamicUpdateInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEncryptionOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEndpoint(Range) - Method in class org.apache.cassandra.client.RingCache
ListMultimap promises to return a List for get(K)
getEndpoint(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
 
getEndpoint(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getEndpointDowntime(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointInfo(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Get the raw information about an end point
getEndpoints(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getEndpointSnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEndpointStateForEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getEndpointStates() - Method in class org.apache.cassandra.gms.Gossiper
 
getEndToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getEntity() - Method in class org.apache.cassandra.cql.Relation
 
getEntryIterator(DecoratedKey) - Method in class org.apache.cassandra.db.Memtable
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.db.ColumnFamily
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
getEstimatedColumnCount() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getEstimatedColumnCount() - Method in interface org.apache.cassandra.io.util.IIterableColumns
 
getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getEstimatedColumnCountHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getEstimatedColumnCountHistogram() - Method in class org.apache.cassandra.db.DataTracker
 
getEstimatedRowSize() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getEstimatedRowSizeHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getEstimatedRowSizeHistogram() - Method in class org.apache.cassandra.db.DataTracker
 
getFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getfd(FileDescriptor) - Static method in class org.apache.cassandra.utils.CLibrary
Get system file descriptor from FileDescriptor object.
getFileDataInput(DecoratedKey, int) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getFileLength() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
getFilename() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getFilename() - Method in class org.apache.cassandra.streaming.PendingFile
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
getFilePointer() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
getFilePointer() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
getFiles(String, String) - Static method in class org.apache.cassandra.db.DefsTable
gets all the files that belong to a given column family.
getFilesDestinedFor(InetAddress) - Method in class org.apache.cassandra.tools.NodeProbe
 
getFilter(SlicePredicate, AbstractType) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getFilter(long, int) - Static method in class org.apache.cassandra.utils.BloomFilter
 
getFilter(long, double) - Static method in class org.apache.cassandra.utils.BloomFilter
 
getFilter(long, int) - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getFilter(long, double) - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getFinish() - Method in class org.apache.cassandra.cql.SelectExpression
 
getFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
 
getFloat(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getFloat(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getFlushLargestMemtablesAt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushPath(long, String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getFlushQueueSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFrom() - Method in interface org.apache.cassandra.net.IAsyncResult
 
getFrom() - Method in class org.apache.cassandra.net.Message
 
getFullColumnFamily() - Method in class org.apache.cassandra.io.PrecompactedRow
 
getFunctionNames() - Static method in enum org.apache.cassandra.cli.CliClient.Function
 
getGcGraceSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getGrammarFileName() - Method in class org.apache.cassandra.cli.CliLexer
 
getGrammarFileName() - Method in class org.apache.cassandra.cli.CliParser
 
getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlLexer
 
getGrammarFileName() - Method in class org.apache.cassandra.cql.CqlParser
 
getHashBuckets(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
getHasToken() - Method in class org.apache.cassandra.gms.EndpointState
 
getHeader(String) - Method in class org.apache.cassandra.net.Message
 
getHeapMemoryUsage() - Method in class org.apache.cassandra.tools.NodeProbe
 
getHintedEndpoints(Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
returns Multimap of {live destination: ultimate targets}, where if target is not the same as the destination, it is a "hinted" write, and will need to be sent to the ultimate target when it becomes alive again.
getHintedHandoffEnabled() - Method in class org.apache.cassandra.service.StorageProxy
 
getHintedHandoffEnabled() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getHintedHandoffThrottleDelay() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getHits() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getHits() - Method in interface org.apache.cassandra.cache.InstrumentingCacheMBean
total cache hit count since cache creation
getHost() - Method in class org.apache.cassandra.streaming.StreamInSession
 
getHost() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
getId(String, String) - Static method in class org.apache.cassandra.config.CFMetaData
 
getIdentityFilter(DecoratedKey, QueryPath) - Static method in class org.apache.cassandra.db.filter.QueryFilter
return a QueryFilter object that includes every column in the row.
getIncomingFiles(String) - Method in class org.apache.cassandra.streaming.StreamingService
details about incoming streams.
getIncomingFiles(String) - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
details about incoming streams
getIncomingFiles(InetAddress) - Static method in class org.apache.cassandra.streaming.StreamInSession
query the status of incoming files.
getIncomingFiles(InetAddress) - Method in class org.apache.cassandra.tools.NodeProbe
 
getIndexAccessMode() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexedColumnFamilyStore(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getIndexedColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getIndexedReadBufferSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexInterval() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexKeyFor(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getIndexName() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getIndexName() - Method in class org.apache.cassandra.cql.CreateIndexStatement
Index name (or null).
getIndexOperator(String) - Static method in class org.apache.cassandra.cli.CliUtils
Returns IndexOperator from string representation
getIndexPositions() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
getIndexType() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getInitialAddress(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInitialToken() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInMemoryCompactionLimit() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSlicePredicate(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInputSplitSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getInt(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getInt(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getInternal(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getInternalReply(byte[], int) - Method in class org.apache.cassandra.net.Message
 
getIterator(Collection<Memtable>, Collection<SSTableReader>, DecoratedKey, DecoratedKey, QueryFilter, AbstractType, ColumnFamilyStore) - Static method in class org.apache.cassandra.db.RowIteratorFactory
Get a row iterator over the provided memtables and sstables, between the provided keys and filtered by the queryfilter.
getJdbcType() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.BytesType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.LongType
 
getJdbcType() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getJmxName() - Method in enum org.apache.cassandra.concurrent.Stage
 
getJmxType() - Method in enum org.apache.cassandra.concurrent.Stage
 
getJobJarLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getJobTrackerAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getJoiningNodes() - Method in class org.apache.cassandra.service.StorageService
 
getJoiningNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of nodes currently bootstrapping into the ring.
getJoiningNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getKey(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKey() - Method in interface org.apache.cassandra.cql.jdbc.CassandraResultSet
 
getKey() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getKey() - Method in class org.apache.cassandra.cql.UpdateStatement
 
getKey() - Method in interface org.apache.cassandra.db.columniterator.IColumnIterator
 
getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
getKey() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
getKey() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getKeyAsBytes(String, Tree) - Method in class org.apache.cassandra.cli.CliClient
 
getKeyCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getKeyCache() - Method in class org.apache.cassandra.db.DataTracker
 
getKeyCache() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeyCacheCapacity() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getKeyCacheMBean(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getKeyCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getKeyCacheSize() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeyCacheSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getKeyFinish() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyName() - Method in class org.apache.cassandra.config.CFMetaData
 
getKeys() - Method in class org.apache.cassandra.cql.DeleteStatement
 
getKeys() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeys() - Method in class org.apache.cassandra.cql.WhereClause
 
getKeySamples() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeySamples(Range) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getKeySet() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getKeySpace() - Method in class org.apache.cassandra.cli.CliClient
 
getKeySpace(Tree, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKeySpace(String, List<KsDef>) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKeyspace() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
getKeyspace() - Method in class org.apache.cassandra.db.ReadCommand
 
getKeyspace() - Method in class org.apache.cassandra.io.CompactionController
 
getKeyspace() - Method in class org.apache.cassandra.io.CompactionInfo
 
getKeyspace() - Method in class org.apache.cassandra.service.ClientState
 
getKeyspace() - Method in interface org.apache.cassandra.service.IReadCommand
 
getKeyspaces() - Method in class org.apache.cassandra.service.StorageService
 
getKeyspaces() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getKeyspaces() - Method in class org.apache.cassandra.tools.NodeProbe
 
getKeyStart() - Method in class org.apache.cassandra.cql.SelectStatement
 
getKeyType() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
getKeyType(String) - Method in class org.apache.cassandra.cql.UpdateStatement
 
getKeyValidator() - Method in class org.apache.cassandra.config.CFMetaData
 
getKSMetaData(String) - Method in class org.apache.cassandra.cli.CliClient
 
getKSMetaData(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLastMigrationId() - Static method in class org.apache.cassandra.db.migration.Migration
 
getLeavingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
caller should not modify leavingEndpoints
getLeavingNodes() - Method in class org.apache.cassandra.service.StorageService
 
getLeavingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of nodes currently leaving the ring.
getLeavingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLength() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getLength() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
Returns the length of the valid data currently in the buffer.
getLength() - Method in class org.apache.cassandra.io.util.OutputBuffer
 
getLifetimeReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLifetimeReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLifetimeWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLifetimeWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLiveDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLiveDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getLiveNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
This method attempts to return N endpoints that are responsible for storing the specified key i.e for replication.
getLiveNaturalEndpoints(String, Token) - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of live nodes in the cluster, where "liveness" is determined by the failure detector of the node being queried.
getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLiveSize() - Method in class org.apache.cassandra.db.DataTracker
 
getLiveSize() - Method in class org.apache.cassandra.db.Memtable
 
getLiveSSTableCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLiveSSTableCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getLoad() - Method in class org.apache.cassandra.service.StorageService
raw load value
getLoad() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Numeric load value.
getLoadInfo() - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
getLoadMap() - Method in class org.apache.cassandra.service.StorageService
 
getLoadMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Human-readable load value.
getLoadMap() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLoadString() - Method in class org.apache.cassandra.service.StorageService
 
getLoadString() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Human-readable load value
getLoadString() - Method in class org.apache.cassandra.tools.NodeProbe
 
getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.Column
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.ColumnFamily
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.DeletedColumn
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.ExpiringColumn
 
getLocalDeletionTime() - Method in interface org.apache.cassandra.db.IColumn
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.SuperColumn
 
getLocalId() - Static method in class org.apache.cassandra.utils.NodeId
 
getLocalMigrations(UUID, UUID) - Static method in class org.apache.cassandra.db.migration.Migration
load serialized migrations.
getLocalPrimaryRange() - Method in class org.apache.cassandra.service.StorageService
 
getLocalRanges(String) - Method in class org.apache.cassandra.service.StorageService
 
getLocalToken() - Method in class org.apache.cassandra.service.StorageService
 
getLocations() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getLong(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getLong(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getMajorVersion() - Method in class org.apache.cassandra.cql.jdbc.CassandraDriver
Returns default major version.
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.Column
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.ColumnFamily
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.DeletedColumn
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.ExpiringColumn
 
getMarkedForDeleteAt() - Method in interface org.apache.cassandra.db.IColumn
 
getMarkedForDeleteAt() - Method in interface org.apache.cassandra.db.IColumnContainer
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.SuperColumn
 
getMaxCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
 
getMaxHintWindow() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMaxHintWindow() - Method in class org.apache.cassandra.service.StorageProxy
 
getMaxHintWindow() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getMaximumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaximumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Gets the maximum number of sstables in queue before compaction kicks off
getMaxRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMaxRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
return the size of the largest compacted row
getMaxRowSize() - Method in class org.apache.cassandra.db.DataTracker
 
getMeanColumns() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanColumns() - Method in class org.apache.cassandra.db.DataTracker
 
getMeanRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMeanRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
return the mean size of the rows compacted
getMeanRowSize() - Method in class org.apache.cassandra.db.DataTracker
 
getMemtable() - Method in class org.apache.cassandra.db.DataTracker
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in interface org.apache.cassandra.db.filter.IFilter
returns an iterator that returns columns from the given memtable matching the Filter criteria in sorted order.
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getMemtableColumnIterator(Memtable, AbstractType) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getMemtableColumnIterator(ColumnFamily, DecoratedKey, AbstractType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getMemtableColumnsCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableColumnsCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns the total number of columns present in the memtable.
getMemtableDataSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableDataSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns the total amount of data stored in the memtable, including column related overhead.
getMemtableFlushAfterMins() - Method in class org.apache.cassandra.config.CFMetaData
 
getMemtableFlushAfterMins() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableFlushAfterMins() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMemtableOperationsInMillions() - Method in class org.apache.cassandra.config.CFMetaData
 
getMemtableOperationsInMillions() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableOperationsInMillions() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtablesPendingFlush() - Method in class org.apache.cassandra.db.DataTracker
 
getMemtableSwitchCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableSwitchCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Returns the number of times that a flush has resulted in the memtable being switched out.
getMemtableThroughputInMb() - Method in class org.apache.cassandra.config.CFMetaData
 
getMemtableThroughputInMB() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMemtableThroughputInMB() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getMergeShardsChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getMessage(Integer) - Method in class org.apache.cassandra.db.IndexScanCommand
 
getMessage(Integer) - Method in class org.apache.cassandra.db.RangeSliceCommand
 
getMessage(Integer) - Method in class org.apache.cassandra.db.ReadCommand
 
getMessage(Integer) - Method in class org.apache.cassandra.db.RowMutation
 
getMessage(Integer) - Method in class org.apache.cassandra.db.Truncation
 
getMessage(Integer) - Method in class org.apache.cassandra.net.CachingMessageProducer
 
getMessage(Integer) - Method in interface org.apache.cassandra.net.MessageProducer
 
getMessageBody() - Method in class org.apache.cassandra.net.Message
 
getMessages() - Method in class org.apache.cassandra.service.AbstractRowResolver
 
getMessages() - Method in interface org.apache.cassandra.service.IResponseResolver
 
getMessages() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
getMessageType() - Method in class org.apache.cassandra.net.Message
 
getMetaData() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
getMetaData() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getMinCompactionThreshold() - Method in class org.apache.cassandra.config.CFMetaData
 
getMinimumCompactionThreshold() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMinimumCompactionThreshold() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Gets the minimum number of sstables in queue before compaction kicks off
getMinimumToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getMinorVersion() - Method in class org.apache.cassandra.cql.jdbc.CassandraDriver
Returns default minor version.
getMinRowSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getMinRowSize() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
return the size of the smallest compacted row
getMinRowSize() - Method in class org.apache.cassandra.db.DataTracker
 
getMovingEndpoints() - Method in class org.apache.cassandra.locator.TokenMetadata
Endpoints which are migrating to the new tokens
getMovingNodes() - Method in class org.apache.cassandra.service.StorageService
 
getMovingNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of nodes currently moving in the ring.
getMovingNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getMsProxy() - Method in class org.apache.cassandra.tools.NodeProbe
 
getName() - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
Name of the column family to create
getName() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
 
getName() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getNamesFilter(DecoratedKey, QueryPath, SortedSet<ByteBuffer>) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getNamesFilter(DecoratedKey, QueryPath, ByteBuffer) - Static method in class org.apache.cassandra.db.filter.QueryFilter
convenience method for creating a name filter matching a single column
getNamesIterator(DecoratedKey, ColumnFamily, NamesQueryFilter) - Static method in class org.apache.cassandra.db.Memtable
 
getNameString() - Method in class org.apache.cassandra.cql.jdbc.TypedColumn
 
getNameType() - Method in class org.apache.cassandra.cql.jdbc.TypedColumn
 
getNaturalEndpoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
get the (possibly cached) endpoints that should store the given Token Note that while the endpoints are conceptually a Set (no duplicates will be included), we return a List to avoid an extra allocation when sorting by proximity later
getNaturalEndpoints(String, byte[]) - Method in class org.apache.cassandra.service.StorageService
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNaturalEndpoints(String, ByteBuffer) - Method in class org.apache.cassandra.service.StorageService
 
getNaturalEndpoints(String, Token) - Method in class org.apache.cassandra.service.StorageService
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNaturalEndpoints(String, byte[]) - Method in interface org.apache.cassandra.service.StorageServiceMBean
This method returns the N endpoints that are responsible for storing the specified key i.e for replication.
getNaturalEndpoints(String, ByteBuffer) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getNextAvailableDataLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
 
getNodeId() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
getNodeProbe() - Method in class org.apache.cassandra.cli.CliSessionState
 
getNodeValue(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getNodeValues(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getNonSystemTables() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getNumRecords() - Method in class org.apache.cassandra.cql.SelectStatement
 
getNumWords() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: gets the number of longs in the array that are in use
getObject(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getObject(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getObject(int, Map<String, Class<?>>) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getObject(String, Map<String, Class<?>>) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getOldLocalNodeIds() - Static method in class org.apache.cassandra.db.SystemTable
 
getOldLocalNodeIds() - Static method in class org.apache.cassandra.utils.NodeId
Return the list of old local node id of this node.
getOpCount() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getOperationMode() - Method in class org.apache.cassandra.service.StorageService
 
getOperationMode() - Method in interface org.apache.cassandra.service.StorageServiceMBean
get the operational mode (leaving, joining, normal, decommissioned, client)
getOperationMode() - Method in class org.apache.cassandra.tools.NodeProbe
 
getOperations() - Method in class org.apache.cassandra.db.Memtable
 
getOutgoingFiles(String) - Method in class org.apache.cassandra.streaming.StreamingService
outgoing streams
getOutgoingFiles(String) - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
outgoing streams
getOutgoingFiles(InetAddress) - Static method in class org.apache.cassandra.streaming.StreamOutSession
 
getOutputColumnFamily(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputCommitter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
The OutputCommitter for this format does not write any data to the DFS.
getOutputKeyspace(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputKeyspacePassword(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOutputKeyspaceUserName(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getOwnership() - Method in class org.apache.cassandra.service.StorageService
 
getOwnership() - Method in interface org.apache.cassandra.service.StorageServiceMBean
given a list of tokens (representing the nodes in the cluster), returns a mapping from "token -> %age of cluster owned by that token"
getOwnership() - Method in class org.apache.cassandra.tools.NodeProbe
 
getParameterMetaData() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitioner(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
 
getPath() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
getPath() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
getPath() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
getPath() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
getPath() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
getPendingAddressRanges(TokenMetadata, Token, InetAddress) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getPendingMessages() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
getPendingRanges(String) - Method in class org.apache.cassandra.locator.TokenMetadata
a mutable map may be returned but caller should not modify it
getPendingRanges(String, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPendingRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getPendingRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve a map of pending ranges to endpoints that describe the ring topology
getPendingTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
Get the number of tasks waiting to be executed
getPendingTasks() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
Get the number of tasks waiting to be executed
getPendingTasks() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getPendingTasks() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getPendingTasks() - Method in class org.apache.cassandra.db.CompactionManager
 
getPendingTasks() - Method in interface org.apache.cassandra.db.CompactionManagerMBean
 
getPhiConvictThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPhiConvictThreshold() - Method in class org.apache.cassandra.gms.FailureDetector
 
getPhiConvictThreshold() - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
getPosition(DecoratedKey, SSTableReader.Operator) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getPosition() - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
getPosition() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
getPosition() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
getPositionsForRanges(Collection<Range>) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Determine the minimal set of sections that can be extracted from this SSTable to cover the given ranges.
getPrecision(Long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
getPrecision(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getPrecision(UUID) - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
getPrecision(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getPrecision(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
getPrecision(BigInteger) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
getPrecision(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getPrecision(Long) - Method in class org.apache.cassandra.db.marshal.LongType
 
getPrecision(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getPredecessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPreheatKeyCache() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPrimaryRangeFor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getPrimaryRangeForEndpoint(InetAddress) - Method in class org.apache.cassandra.service.StorageService
Get the primary range for the specified endpoint.
getProgress() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
getPropertyInfo(String, Properties) - Method in class org.apache.cassandra.cql.jdbc.CassandraDriver
Returns default driver property info object.
getProtectedField(Class, String) - Static method in class org.apache.cassandra.utils.FBUtilities
Used to get access to protected/private field of the specified class
getProtocol(TTransport) - Method in class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
getRack(InetAddress) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Return the rack for which an endpoint resides in
getRack(InetAddress) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getRack(InetAddress) - Method in class org.apache.cassandra.locator.Ec2Snitch
 
getRack(String) - Method in class org.apache.cassandra.locator.EndpointSnitchInfo
 
getRack(String) - Method in interface org.apache.cassandra.locator.EndpointSnitchInfoMBean
Provides the Rack name depending on the respective snitch used, given the host name/ip
getRack(InetAddress) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a String repesenting the rack this endpoint belongs to
getRack(InetAddress) - Method in class org.apache.cassandra.locator.PropertyFileSnitch
Return the rack for which an endpoint resides in
getRack(InetAddress) - Method in class org.apache.cassandra.locator.RackInferringSnitch
 
getRack(InetAddress) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getRandomToken() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getRandomToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getRandomToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getRange(ByteBuffer) - Method in class org.apache.cassandra.client.RingCache
 
getRangeAddresses(TokenMetadata) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getRangeBatchSize(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
The number of rows to request with each get range slices request.
getRangeOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getRangeOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRangeSlice(ByteBuffer, AbstractBounds, int, IFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Fetch a range of rows and columns from memtables/sstables.
getRangeSlice(RangeSliceCommand, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
getRangeToAddressMap(String) - Method in class org.apache.cassandra.service.StorageService
 
getRangeToEndpointMap(String) - Method in class org.apache.cassandra.service.StorageService
for a keyspace, return the ranges and corresponding hosts for a given keyspace.
getRangeToEndpointMap(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve a map of range to end points that describe the ring topology of a Cassandra cluster.
getRawCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
raw cached row -- does not fetch the row if it is not present.
getRawColumn() - Method in class org.apache.cassandra.cql.jdbc.TypedColumn
 
getRawInputSlicePredicate(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getReadConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getReadCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getReadCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadRepairChance() - Method in class org.apache.cassandra.config.CFMetaData
 
getRecentBloomFilterFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentBloomFilterFalsePositives() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentBloomFilterFalsePositives() - Method in class org.apache.cassandra.db.DataTracker
 
getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentBloomFilterFalseRatio() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentBloomFilterFalseRatio() - Method in class org.apache.cassandra.db.DataTracker
 
getRecentBloomFilterTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getRecentFalsePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentHitRate() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getRecentHitRate() - Method in interface org.apache.cassandra.cache.InstrumentingCacheMBean
hits / requests since the last time getHitRate was called.
getRecentLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getRecentLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
returns microseconds
getRecentRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRecentWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getRecentWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlLexer
 
getRecognitionErrors() - Method in class org.apache.cassandra.cql.CqlParser
 
getRecordWriter(FileSystem, JobConf, String, Progressable) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Deprecated. 
getRecordWriter(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
Get the RecordWriter for the given task.
getReduceCacheCapacityTo() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReduceCacheSizesAt() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReduced() - Method in class org.apache.cassandra.io.CompactionIterator
 
getReduced() - Method in class org.apache.cassandra.utils.ReducingIterator
return the last object computed by reduce
getRegisteredCallbackAge(String) - Method in class org.apache.cassandra.net.MessagingService
 
getReleaseVersion() - Method in class org.apache.cassandra.service.StorageService
 
getReleaseVersion() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch a string representation of the Cassandra version.
getReleaseVersion() - Method in class org.apache.cassandra.tools.NodeProbe
 
getReleaseVersionString() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getRemovalStatus() - Method in class org.apache.cassandra.service.StorageService
Get the status of a token removal.
getRemovalStatus() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Get the status of a token removal.
getRemovalStatus() - Method in class org.apache.cassandra.tools.NodeProbe
 
getRepairSession(Range, String, String...) - Method in class org.apache.cassandra.service.AntiEntropyService
Requests repairs for the given table and column families, and blocks until all repairs have been completed.
getReplayPosition(Iterable<? extends SSTable>) - Static method in class org.apache.cassandra.db.commitlog.ReplayPosition
Convenience method to compute the replay position for a group of SSTables.
getReplicateOnWrite() - Method in class org.apache.cassandra.config.CFMetaData
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
calculate the RF based on strategy_options.
getReplicationFactor() - Method in class org.apache.cassandra.locator.LocalStrategy
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getReplicationFactor(String) - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
getReplicationFactor() - Method in class org.apache.cassandra.locator.SimpleStrategy
 
getReplicationStrategy() - Method in class org.apache.cassandra.db.Table
 
getReply(Message) - Method in class org.apache.cassandra.db.RangeSliceReply
 
getReply(InetAddress, byte[], int) - Method in class org.apache.cassandra.net.Message
 
getRequestedNodeList(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getRequests() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
getRequests() - Method in interface org.apache.cassandra.cache.InstrumentingCacheMBean
total request count since cache creation
getRequestScheduler() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRequestSchedulerId() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRequestSchedulerOptions() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getResetInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getResetInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getResponse(ReadCommand, Row) - Static method in class org.apache.cassandra.db.ReadVerbHandler
 
getResponseCompletedTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getResponseCompletedTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Completed tasks for Response(GOSSIP & RESPONSE) TCP Connections
getResponsePendingTasks() - Method in class org.apache.cassandra.net.MessagingService
 
getResponsePendingTasks() - Method in interface org.apache.cassandra.net.MessagingServiceMBean
Pending tasks for Response(GOSSIP & RESPONSE) TCP Connections
getReverseComparator() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getReverseSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
 
getRow() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getRow(Table) - Method in class org.apache.cassandra.db.ReadCommand
 
getRow(Table) - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
getRow(Table) - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
getRow(QueryFilter) - Method in class org.apache.cassandra.db.Table
 
getRowCacheCapacity() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRowCacheMBean(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
getRowCacheProvider() - Method in class org.apache.cassandra.config.CFMetaData
 
getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.config.CFMetaData
 
getRowCacheSavePeriodInSeconds() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRowCacheSavePeriodInSeconds() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getRowCacheSize() - Method in class org.apache.cassandra.config.CFMetaData
 
getRowCacheSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getRpcAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcKeepAlive() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcMinThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcPort(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getRpcRecvBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcSendBufferSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSavedCachesLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSavedToken() - Static method in class org.apache.cassandra.db.SystemTable
 
getScale(Long) - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
getScale(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getScale(UUID) - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
getScale(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getScale(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
getScale(BigInteger) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
getScale(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getScale(Long) - Method in class org.apache.cassandra.db.marshal.LongType
 
getScale(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getScanner(int, QueryFilter) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
getScanners() - Method in class org.apache.cassandra.io.CompactionIterator
 
getSchedulingValue() - Method in class org.apache.cassandra.service.ClientState
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.CfDef
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.ColumnDef
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.KsDef
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.Migration
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.RenameKeyspace
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
getSchema() - Method in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
getScores() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getScores() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSeeds() - Method in interface org.apache.cassandra.locator.SeedProvider
 
getSeeds() - Method in class org.apache.cassandra.locator.SimpleSeedProvider
 
getSegment(long, int) - Method in class org.apache.cassandra.io.util.BufferedSegmentedFile
 
getSegment(long, int) - Method in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
getSegment(long, int) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
getSerializedBuffer(int) - Method in class org.apache.cassandra.db.RowMutation
 
getSerializedCachePath(String, String, ColumnFamilyStore.CacheType) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSerializedSize() - Method in class org.apache.cassandra.db.Memtable
 
getServerSocket(EncryptionOptions, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
 
getSessionId() - Method in class org.apache.cassandra.streaming.StreamInSession
 
getSessionId() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
getSlicedReadBufferSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSliceFilter(DecoratedKey, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
getSliceIterator(DecoratedKey, ColumnFamily, SliceQueryFilter, AbstractType) - Static method in class org.apache.cassandra.db.Memtable
obtain an iterator of columns in this memtable in the specified order starting from a given column.
getSnapshotPath(String, String, String) - Static method in class org.apache.cassandra.db.Table
 
getSocket(EncryptionOptions, InetAddress, int, InetAddress, int) - Static method in class org.apache.cassandra.security.SSLFactory
Create a socket and connect
getSocket(EncryptionOptions) - Static method in class org.apache.cassandra.security.SSLFactory
Just create a socket
getSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
 
getSortedColumns() - Method in interface org.apache.cassandra.db.IColumnContainer
 
getSortedColumns() - Method in class org.apache.cassandra.db.SuperColumn
 
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Sorts the Collection of node addresses by proximity to the given address
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
returns a new List sorted by proximity to the given endpoint
getSortedListByProximity(InetAddress, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
getSources() - Static method in class org.apache.cassandra.streaming.StreamInSession
query method to determine which hosts are streaming to this node.
getSplits(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyInputFormat
 
getSplits(String, String, Range, int) - Method in class org.apache.cassandra.service.StorageService
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IFilter
Get an iterator that returns columns from the given SSTable using the opened file matching the Filter criteria in sorted order.
getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in interface org.apache.cassandra.db.filter.IFilter
returns an iterator that returns columns from the given SSTable matching the Filter criteria in sorted order.
getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getSSTableColumnIterator(SSTableReader, DecoratedKey) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTableColumnIterator(SSTableReader, FileDataInput, DecoratedKey) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTables() - Method in class org.apache.cassandra.db.DataTracker
 
getSSTablesPerReadHistogram() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getSSTablesPerReadHistogram() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getStage(Stage) - Static method in class org.apache.cassandra.concurrent.StageManager
Retrieve a stage from the StageManager
getStart() - Method in class org.apache.cassandra.cql.SelectExpression
 
getStartKey() - Method in class org.apache.cassandra.cql.WhereClause
 
getStartToken() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
getStatement() - Method in class org.apache.cassandra.cli.CliParser
 
getStatus() - Method in class org.apache.cassandra.streaming.StreamingService
 
getStatus() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
What's currently happening wrt streaming.
getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStrategyClass() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
 
getStrategyOptions() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
 
getStreamDestinations() - Method in class org.apache.cassandra.streaming.StreamingService
hosts receiving outgoing streams.
getStreamDestinations() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
hosts recieving outgoing streams
getStreamDestinations() - Method in class org.apache.cassandra.tools.NodeProbe
 
getStreamSources() - Method in class org.apache.cassandra.streaming.StreamingService
hosts sending incoming streams
getStreamSources() - Method in interface org.apache.cassandra.streaming.StreamingServiceMBean
hosts sending incoming streams.
getStreamSources() - Method in class org.apache.cassandra.tools.NodeProbe
 
getString(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getString(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getString(AbstractType) - Method in class org.apache.cassandra.db.Column
 
getString(AbstractType) - Method in class org.apache.cassandra.db.CounterColumn
 
getString(AbstractType) - Method in class org.apache.cassandra.db.ExpiringColumn
 
getString(AbstractType) - Method in interface org.apache.cassandra.db.IColumn
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a string representation of the bytes suitable for log messages
getString(Collection<ByteBuffer>) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
getString(AbstractType) - Method in class org.apache.cassandra.db.SuperColumn
 
getSubColumn(ByteBuffer) - Method in class org.apache.cassandra.db.Column
 
getSubColumn(ByteBuffer) - Method in interface org.apache.cassandra.db.IColumn
 
getSubColumn(ByteBuffer) - Method in class org.apache.cassandra.db.SuperColumn
 
getSubColumns() - Method in class org.apache.cassandra.db.Column
 
getSubColumns() - Method in interface org.apache.cassandra.db.IColumn
 
getSubColumns() - Method in class org.apache.cassandra.db.SuperColumn
 
getSubComparator(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSubComparator() - Method in class org.apache.cassandra.db.ColumnFamily
 
getSubsnitchClassName() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getSubsnitchClassName() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getSuccessor(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getSuccessor(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
getTable() - Method in class org.apache.cassandra.db.CounterMutation
 
getTable() - Method in interface org.apache.cassandra.db.IMutation
 
getTable() - Method in class org.apache.cassandra.db.RowMutation
 
getTableDefinition(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTableMetaData(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTableName() - Method in class org.apache.cassandra.db.Memtable
 
getTableName() - Method in class org.apache.cassandra.io.sstable.SSTable
 
getTables() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTaskType() - Method in class org.apache.cassandra.io.CompactionInfo
 
getTaskType() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTempSSTablePath(String, String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTempSSTablePath(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getText() - Method in class org.apache.cassandra.cql.Term
Returns the text parsed to create this term.
getThreadPoolMBeanProxies() - Method in class org.apache.cassandra.tools.NodeProbe
 
getThriftFramedTransportSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getThriftMaxMessageLength() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTime(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTime(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTime(int, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTime(String, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTimestamp(int) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTimestamp(String) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTimestamp(int, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTimestamp(String, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getTimestampedSnapshotName(String) - Static method in class org.apache.cassandra.db.Table
 
getTimeToLive() - Method in class org.apache.cassandra.db.ExpiringColumn
 
getTimeUUIDBytes() - Static method in class org.apache.cassandra.utils.UUIDGen
Returns a 16 byte representation of a type 1 UUID (a time-based UUID), based on the current system time.
getTimeUUIDBytes(long) - Static method in class org.apache.cassandra.utils.UUIDGen
Converts a milliseconds-since-epoch timestamp into the 16 byte representation of a type 1 UUID (a time-based UUID).
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.ByteOrderedPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getToken(ByteBuffer) - Method in interface org.apache.cassandra.dht.IPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getToken(ByteBuffer) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getToken(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getToken() - Method in class org.apache.cassandra.service.StorageService
 
getToken() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Fetch a string representation of the token.
getToken() - Method in class org.apache.cassandra.tools.NodeProbe
 
getTokenFactory() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getTokenFactory() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getTokenMetadata() - Method in class org.apache.cassandra.service.StorageService
 
getTokenNames() - Method in class org.apache.cassandra.cli.CliParser
 
getTokenNames() - Method in class org.apache.cassandra.cql.CqlParser
 
getTokenToEndpointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
Return the Token to Endpoint map for all the node in the cluster, including bootstrapping ones.
getTokenToEndpointMap() - Method in class org.apache.cassandra.service.StorageService
 
getTokenToEndpointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve a map of tokens to endpoints, including the bootstrapping ones.
getTokenToEndpointMap() - Method in class org.apache.cassandra.tools.NodeProbe
 
getTotalBytes() - Method in class org.apache.cassandra.io.CompactionInfo
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.KeyIterator
 
getTotalBytes() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
getTotalBytes(Iterable<SSTableReader>) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
getTotalDiskSpaceUsed() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalDiskSpaceUsed() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalLatencyHistogramMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
 
getTotalLatencyMicros() - Method in class org.apache.cassandra.utils.LatencyTracker
returns microseconds
getTotalMemtableLiveSize() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalMemtableSpaceInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTotalRangeLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalRangeLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalRangeLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalRangeLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalReadLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalReadLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalReadLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalSize() - Method in class org.apache.cassandra.db.DataTracker
 
getTotalWriteLatencyHistogramMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalWriteLatencyHistogramMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getTotalWriteLatencyMicros() - Method in class org.apache.cassandra.service.StorageProxy
 
getTotalWriteLatencyMicros() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.addColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.addKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.arrayConstruct_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.assumeStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attr_name_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValue_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueDouble_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueInt_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.attrValueString_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnFamilyExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.columnOrSuperColumn_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.command_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.comparator_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.connectStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.consistencyLevelStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.countStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.delColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.delKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.delStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.describeCluster_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.describeTable_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.endKey_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.exitStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.functionArgument_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.functionCall_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.getCondition_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.getStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.hashConstruct_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.hashElementPair_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.helpStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.host_name_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.host_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.incrementValue_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.incrStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.ip_address_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyRangeExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyspaceNewName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePair_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.keyValuePairExpr_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.listStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.newColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.objectName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.operator_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.password_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.port_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.replica_placement_strategy_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.root_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.rowKey_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.setStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showClusterName_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showKeyspaces_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.showVersion_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.startKey_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.statement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.truncateStatement_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.typeIdentifier_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.updateColumnFamily_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.updateKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.useKeyspace_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.username_return
 
getTree() - Method in class org.apache.cassandra.cli.CliParser.value_return
 
getTreeAdaptor() - Method in class org.apache.cassandra.cli.CliParser
 
getTruePositiveCount() - Method in class org.apache.cassandra.io.sstable.BloomFilterTracker
 
getType() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
getType() - Method in class org.apache.cassandra.cql.Term
Obtain the term's type.
getType() - Method in class org.apache.cassandra.db.ColumnFamily
 
getType() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
getType() - Method in class org.apache.cassandra.db.marshal.AbstractType
returns the class this AbstractType represents.
getType() - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
getType() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getType() - Method in class org.apache.cassandra.db.marshal.BytesType
 
getType() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
getType() - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
getType() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
getType() - Method in class org.apache.cassandra.db.marshal.LongType
 
getType() - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
getType() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getType() - Method in class org.apache.cassandra.db.marshal.UUIDType
 
getTypeByFunction(String) - Static method in class org.apache.cassandra.cli.CliClient
Get AbstractType by function name
getUncachingReader(String) - Static method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
getUnreachableMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getUnreachableNodes() - Method in class org.apache.cassandra.service.StorageService
 
getUnreachableNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Retrieve the list of unreachable nodes in the cluster, as determined by this node's failure detector.
getUnreachableNodes() - Method in class org.apache.cassandra.tools.NodeProbe
 
getUpdateInterval() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
getUpdateInterval() - Method in interface org.apache.cassandra.locator.DynamicEndpointSnitchMBean
 
getUpdates() - Method in class org.apache.cassandra.cql.BatchUpdateStatement
 
getUptime() - Method in class org.apache.cassandra.tools.NodeProbe
 
getUsername() - Method in class org.apache.cassandra.cli.CliClient
 
getUUID(ByteBuffer) - Static method in class org.apache.cassandra.utils.UUIDGen
creates a type 1 uuid from raw bytes.
getValidator() - Method in enum org.apache.cassandra.cli.CliClient.Function
 
getValidator() - Method in class org.apache.cassandra.config.ColumnDefinition
 
getValidByte(long) - Method in class org.apache.cassandra.cache.FreeableMemory
 
getValidColumnFamilies(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
getValue() - Method in class org.apache.cassandra.cql.jdbc.TypedColumn
 
getValue() - Method in class org.apache.cassandra.cql.Relation
 
getValueString() - Method in class org.apache.cassandra.cql.jdbc.TypedColumn
 
getValueType() - Method in class org.apache.cassandra.cql.jdbc.TypedColumn
 
getValueValidator(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
getValueValidator(String, String, ByteBuffer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getValueValidator(String, ByteBuffer) - Method in class org.apache.cassandra.cql.SelectStatement
 
getValueValidator(String, ByteBuffer) - Method in class org.apache.cassandra.cql.UpdateStatement
 
getVerb() - Method in class org.apache.cassandra.net.Message
 
getVerbHandler(StorageService.Verb) - Method in class org.apache.cassandra.net.MessagingService
This method returns the verb handler associated with the registered verb.
getVersion() - Method in class org.apache.cassandra.db.migration.Migration
 
getVersion(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
getVersion() - Method in class org.apache.cassandra.net.Message
 
GetVersion - Class in org.apache.cassandra.tools
 
GetVersion() - Constructor for class org.apache.cassandra.tools.GetVersion
 
getView() - Method in class org.apache.cassandra.db.DataTracker
 
getWorkMap(Multimap<Range, InetAddress>) - Static method in class org.apache.cassandra.dht.BootStrapper
 
getWriteConsistencyLevel(Configuration) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
getWriteCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getWriteCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getWriteEndpoints(Token, String, Collection<InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
write endpoints may be different from read endpoints, because read endpoints only need care about the "natural" nodes for a token, but write endpoints also need to account for nodes that are bootstrapping into the ring, and write data there too so that they stay up to date during the bootstrap process.
getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getWriter() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
getWriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
GossipDigest - Class in org.apache.cassandra.gms
Contains information about a specified list of Endpoints and the largest version of the state they have generated as known by the local endpoint.
GossipDigestAck2VerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestAck2VerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAck2VerbHandler
 
GossipDigestAckVerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestAckVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestAckVerbHandler
 
GossipDigestSynVerbHandler - Class in org.apache.cassandra.gms
 
GossipDigestSynVerbHandler() - Constructor for class org.apache.cassandra.gms.GossipDigestSynVerbHandler
 
Gossiper - Class in org.apache.cassandra.gms
This module is responsible for Gossiping information for the local endpoint.
gossiperStarting() - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
gossiperStarting() - Method in class org.apache.cassandra.locator.Ec2Snitch
 
gossiperStarting() - Method in interface org.apache.cassandra.locator.IEndpointSnitch
called after Gossiper instance exists immediately before it starts gossiping
groups - Variable in class org.apache.cassandra.auth.AuthenticatedUser
 
GT - Static variable in class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
guid() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
guidAsBytes() - Static method in class org.apache.cassandra.utils.GuidGenerator
 
GuidGenerator - Class in org.apache.cassandra.utils
 
GuidGenerator() - Constructor for class org.apache.cassandra.utils.GuidGenerator
 
guidToString(byte[]) - Static method in class org.apache.cassandra.utils.GuidGenerator
 

H

H - Static variable in class org.apache.cassandra.cql.CqlLexer
 
H - Static variable in class org.apache.cassandra.cql.CqlParser
 
handleMessage(Message, String, InetAddress) - Method in interface org.apache.cassandra.net.sink.IMessageSink
 
hasColumnFamilyAccess(String, Permission) - Method in class org.apache.cassandra.service.ClientState
Confirms that the client thread has the given Permission in the context of the given ColumnFamily and the current keyspace.
hasColumnFamilyListAccess(Permission) - Method in class org.apache.cassandra.service.ClientState
Confirms that the client thread has the given Permission for the ColumnFamily list of the current keyspace.
hasEncodedKeys - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
HASH - Static variable in class org.apache.cassandra.cli.CliLexer
 
HASH - Static variable in class org.apache.cassandra.cli.CliParser
 
hash(ByteBuffer...) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hash(Range) - Method in class org.apache.cassandra.utils.MerkleTree
Hash the given range in the tree.
hash - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
hash(byte[]) - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
hash() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
hash32(ByteBuffer, int, int, int) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hash64(ByteBuffer, int, int, long) - Static method in class org.apache.cassandra.utils.MurmurHash
 
hashCode() - Method in class org.apache.cassandra.config.CFMetaData
 
hashCode() - Method in class org.apache.cassandra.config.ColumnDefinition
 
hashCode() - Method in class org.apache.cassandra.config.KSMetaData
 
hashCode() - Method in class org.apache.cassandra.db.Column
 
hashCode() - Method in class org.apache.cassandra.db.ColumnFamily
 
hashCode() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
hashCode() - Method in class org.apache.cassandra.db.CounterColumn
 
hashCode() - Method in class org.apache.cassandra.db.DecoratedKey
 
hashCode() - Method in class org.apache.cassandra.dht.AbstractBounds
 
hashCode() - Method in class org.apache.cassandra.dht.BytesToken
 
hashCode() - Method in class org.apache.cassandra.dht.LocalToken
 
hashCode() - Method in class org.apache.cassandra.dht.Token
 
hashCode - Variable in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Component
 
hashCode() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
hashCode() - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
hashCode() - Method in class org.apache.cassandra.streaming.PendingFile
 
hashCode() - Method in class org.apache.cassandra.utils.NodeId
 
hashCode() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
hashCode() - Method in class org.apache.cassandra.utils.Pair
 
hashConstruct() - Method in class org.apache.cassandra.cli.CliParser
 
hashdepth - Variable in class org.apache.cassandra.utils.MerkleTree
 
hashElementPair() - Method in class org.apache.cassandra.cli.CliParser
 
hashToBigInteger(ByteBuffer) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hasIntRowSize - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasKeyspaceListAccess(Permission) - Method in class org.apache.cassandra.service.ClientState
Confirms that the client thread has the given Permission for the Keyspace list.
hasNext() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
hasNext() - Method in class org.apache.cassandra.db.RowIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableBoundedScanner.BoundedKeyScanningIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableBoundedScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
hasNext() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
hasNext() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
hasNodeId(ByteBuffer, NodeId) - Method in class org.apache.cassandra.db.context.CounterContext
Checks whether the provided context has a count for the provided NodeId.
hasNodeId(NodeId) - Method in class org.apache.cassandra.db.CounterColumn
Check if a given nodeId is found in this CounterColumn context.
hasRemaining() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
hasReplayPosition() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
hasStringsInBloomFilter - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
hasUnreclaimedSpace() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
Header - Class in org.apache.cassandra.net
 
header - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
headerLength - Variable in class org.apache.cassandra.db.context.CounterContext.ContextState
 
HeaderTypes - Class in org.apache.cassandra.net
 
HeaderTypes() - Constructor for class org.apache.cassandra.net.HeaderTypes
 
headMap(ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
help - Variable in class org.apache.cassandra.cli.CliCommandHelp
 
HELP - Static variable in class org.apache.cassandra.cli.CliLexer
 
HELP - Static variable in class org.apache.cassandra.cli.CliParser
 
help - Variable in class org.apache.cassandra.cli.CliUserHelp
 
helpStatement() - Method in class org.apache.cassandra.cli.CliParser
 
HEX - Static variable in class org.apache.cassandra.cql.CqlLexer
 
HEX - Static variable in class org.apache.cassandra.cql.CqlParser
 
HexDigit - Static variable in class org.apache.cassandra.cli.CliLexer
 
HexDigit - Static variable in class org.apache.cassandra.cli.CliParser
 
HexEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
HexEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
HINT - Static variable in class org.apache.cassandra.db.RowMutation
 
hinted_handoff_enabled - Variable in class org.apache.cassandra.config.Config
 
hinted_handoff_throttle_delay_in_ms - Variable in class org.apache.cassandra.config.Config
 
hintedEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
hintedHandoffEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
HintedHandOffManager - Class in org.apache.cassandra.db
For each endpoint for which we have hints, there is a row in the system hints CF.
HintedHandOffManager() - Constructor for class org.apache.cassandra.db.HintedHandOffManager
 
HintedHandOffManagerMBean - Interface in org.apache.cassandra.db
 
HINTS_CF - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
HintsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
HISTORYFILE - Static variable in class org.apache.cassandra.cli.CliMain
 
host() - Method in class org.apache.cassandra.cli.CliParser
 
host_name() - Method in class org.apache.cassandra.cli.CliParser
 
hostName - Variable in class org.apache.cassandra.cli.CliSessionState
 

I

I - Static variable in class org.apache.cassandra.cql.CqlLexer
 
I - Static variable in class org.apache.cassandra.cql.CqlParser
 
IAsyncCallback - Interface in org.apache.cassandra.net
implementors of IAsyncCallback need to make sure that any public methods are threadsafe with respect to response() being called from the message service.
IAsyncResult - Interface in org.apache.cassandra.net
 
IAuthenticator - Interface in org.apache.cassandra.auth
 
IAuthority - Interface in org.apache.cassandra.auth
Cassandra's resource hierarchy looks something like: {{/cassandra/keyspaces/$ks_name/...}} In table form: /cassandra/ - no checked permissions - String * Separates Cassandra-internal resources from resources that might be provided by plugins.
ICache<K,V> - Interface in org.apache.cassandra.cache
This is similar to the Map interface, but requires maintaining a given capacity and does not require put or remove to return values, which lets SerializingCache be more efficient by avoiding deserialize except on get.
IColumn - Interface in org.apache.cassandra.db
 
IColumnContainer - Interface in org.apache.cassandra.db
 
IColumnIterator - Interface in org.apache.cassandra.db.columniterator
 
IColumnSerializer - Interface in org.apache.cassandra.io
 
ICommitLogExecutorService - Interface in org.apache.cassandra.db.commitlog
Like ExecutorService, but customized for batch and periodic commitlog execution.
ICompactSerializer<T> - Interface in org.apache.cassandra.io
Allows for the controlled serialization/deserialization of a given type.
ICompactSerializer2<T> - Interface in org.apache.cassandra.io
 
ICompactSerializer3<T> - Interface in org.apache.cassandra.io
 
IContext - Interface in org.apache.cassandra.db.context
An opaque commutative context.
IContext.ContextRelationship - Enum in org.apache.cassandra.db.context
 
id - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
id() - Method in class org.apache.cassandra.db.ColumnFamily
 
id - Variable in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
id - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
id - Variable in class org.apache.cassandra.io.sstable.Component
 
id - Variable in class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
IDENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
IDENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
Identifier - Static variable in class org.apache.cassandra.cli.CliLexer
 
Identifier - Static variable in class org.apache.cassandra.cli.CliParser
 
IdentityQueryFilter - Class in org.apache.cassandra.db.columniterator
 
IdentityQueryFilter() - Constructor for class org.apache.cassandra.db.columniterator.IdentityQueryFilter
Only for use in testing; will read entire CF into memory.
idFromFilename(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
IEndpointSnitch - Interface in org.apache.cassandra.locator
This interface helps determine location of node in the data center relative to another node.
IEndpointStateChangeSubscriber - Interface in org.apache.cassandra.gms
This is called by an instance of the IEndpointStateChangePublisher to notify interested parties about changes in the the state associated with any endpoint.
IExecutorMBean - Interface in org.apache.cassandra.concurrent
 
IFailureDetectionEventListener - Interface in org.apache.cassandra.gms
Implemented by the Gossiper to convict an endpoint based on the PHI calculated by the Failure Detector on the inter-arrival times of the heart beats.
IFailureDetector - Interface in org.apache.cassandra.gms
An interface that provides an application with the ability to query liveness information of a node in the cluster.
IFailureNotification - Interface in org.apache.cassandra.gms
 
IFilter - Interface in org.apache.cassandra.db.filter
Given an implementation-specific description of what columns to look for, provides methods to extract the desired columns from a Memtable, SSTable, or SuperColumn.
IFlushable - Interface in org.apache.cassandra.db
 
IIterableColumns - Interface in org.apache.cassandra.io.util
 
ILatencySubscriber - Interface in org.apache.cassandra.locator
 
IMessageCallback - Interface in org.apache.cassandra.net
 
IMessageSink - Interface in org.apache.cassandra.net.sink
 
importJson(String, String, String, String) - Static method in class org.apache.cassandra.tools.SSTableImport
Convert a JSON formatted file to an SSTable.
importSorted(String, ColumnFamily, String, IPartitioner<?>) - Static method in class org.apache.cassandra.tools.SSTableImport
 
IMutation - Interface in org.apache.cassandra.db
 
in - Variable in class org.apache.cassandra.cli.CliSessionState
 
in_memory_compaction_limit_in_mb - Variable in class org.apache.cassandra.config.Config
 
includeFinishKey() - Method in class org.apache.cassandra.cql.SelectStatement
 
includeFinishKey() - Method in class org.apache.cassandra.cql.WhereClause
 
includeStartKey() - Method in class org.apache.cassandra.cql.SelectStatement
 
includeStartKey() - Method in class org.apache.cassandra.cql.WhereClause
 
IncomingStreamReader - Class in org.apache.cassandra.streaming
 
IncomingStreamReader(StreamHeader, Socket) - Constructor for class org.apache.cassandra.streaming.IncomingStreamReader
 
IncomingTcpConnection - Class in org.apache.cassandra.net
 
IncomingTcpConnection(Socket) - Constructor for class org.apache.cassandra.net.IncomingTcpConnection
 
INCR - Static variable in class org.apache.cassandra.cli.CliLexer
 
INCR - Static variable in class org.apache.cassandra.cli.CliParser
 
incremental_backups - Variable in class org.apache.cassandra.config.Config
 
incrementalBackupsEnabled() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
incrementallyBackup(SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
incrementAndGetGeneration() - Static method in class org.apache.cassandra.db.SystemTable
 
incrementDroppedMessages(StorageService.Verb) - Method in class org.apache.cassandra.net.MessagingService
 
incrementRowid() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
incrementValue() - Method in class org.apache.cassandra.cli.CliParser
 
incrStatement() - Method in class org.apache.cassandra.cli.CliParser
 
INDEX_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
index_clause - Variable in class org.apache.cassandra.db.IndexScanCommand
 
index_interval - Variable in class org.apache.cassandra.config.Config
 
index_name - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
index_type - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
IndexCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
indexComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
indexFor(ByteBuffer, List<IndexHelper.IndexInfo>, AbstractType, boolean) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
The index of the IndexInfo in which a scan starting with @name should begin.
IndexHelper - Class in org.apache.cassandra.io.sstable
Provides helper to serialize, deserialize and use column indexes.
IndexHelper() - Constructor for class org.apache.cassandra.io.sstable.IndexHelper
 
IndexHelper.IndexInfo - Class in org.apache.cassandra.io.sstable
 
IndexHelper.IndexInfo(ByteBuffer, ByteBuffer, long, long) - Constructor for class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
indexName(String, ColumnDefinition) - Static method in class org.apache.cassandra.config.CFMetaData
convention for nameing secondary indexes.
indexPosition - Variable in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
indexReverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
IndexScanCommand - Class in org.apache.cassandra.db
 
IndexScanCommand(String, String, IndexClause, SlicePredicate, AbstractBounds) - Constructor for class org.apache.cassandra.db.IndexScanCommand
 
IndexScanVerbHandler - Class in org.apache.cassandra.service
 
IndexScanVerbHandler() - Constructor for class org.apache.cassandra.service.IndexScanVerbHandler
 
IndexSummary - Class in org.apache.cassandra.io.sstable
Two approaches to building an IndexSummary: 1.
IndexSummary(long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary
 
IndexSummary.KeyPosition - Class in org.apache.cassandra.io.sstable
This is a simple container for the index Key and its corresponding position in the index file.
IndexSummary.KeyPosition(DecoratedKey, long) - Constructor for class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
IndexType - Enum in org.apache.cassandra.db.migration.avro
 
inFileMode() - Method in class org.apache.cassandra.cli.CliSessionState
 
inflate(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
inflate(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
inflate(KsDef) - Static method in class org.apache.cassandra.config.KSMetaData
 
init(String[]) - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Initialize the Cassandra Daemon based on the given Commons Daemon-specific arguments.
init(String[]) - Method in interface org.apache.cassandra.service.CassandraDaemon
Initialize the Cassandra Daemon based on the given Commons Daemon-specific arguments.
init() - Method in class org.apache.cassandra.utils.MerkleTree
Initializes this tree by splitting it until hashdepth is reached, or until an additional level of splits would violate maxsize.
initCaches() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
initCf(Integer, String) - Method in class org.apache.cassandra.db.Table
adds a cf to internal structures, ends up creating disk files).
initClient() - Method in class org.apache.cassandra.service.StorageService
 
initial_token - Variable in class org.apache.cassandra.config.Config
 
INITIAL_VERSION - Static variable in class org.apache.cassandra.config.DatabaseDescriptor
 
initialize(InputSplit, TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
initializeNodeUnsafe(InetAddress, int) - Method in class org.apache.cassandra.gms.Gossiper
This should *only* be used for testing purposes.
initServer() - Method in class org.apache.cassandra.service.StorageService
 
injectPreProcessed(ReadResponse) - Method in class org.apache.cassandra.service.AbstractRowResolver
hack so local reads don't force de/serialization of an extra real Message
inputStream(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
insert(ByteBuffer, ColumnParent, Column, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
insertStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
instance - Static variable in class org.apache.cassandra.db.commitlog.CommitLog
 
instance - Static variable in class org.apache.cassandra.db.CompactionManager
 
instance() - Static method in class org.apache.cassandra.db.context.CounterContext
 
instance - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
instance - Static variable in class org.apache.cassandra.db.marshal.AsciiType
 
instance - Static variable in class org.apache.cassandra.db.marshal.BytesType
 
instance - Static variable in class org.apache.cassandra.db.marshal.CounterColumnType
 
instance - Static variable in class org.apache.cassandra.db.marshal.IntegerType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.LongType
 
instance - Static variable in class org.apache.cassandra.db.marshal.TimeUUIDType
 
instance - Static variable in class org.apache.cassandra.db.marshal.UTF8Type
 
instance - Static variable in class org.apache.cassandra.db.marshal.UUIDType
 
instance - Static variable in class org.apache.cassandra.gms.FailureDetector
 
instance - Static variable in class org.apache.cassandra.gms.Gossiper
 
instance() - Static method in class org.apache.cassandra.net.MessagingService
 
instance - Static variable in class org.apache.cassandra.service.AntiEntropyService
 
instance - Static variable in class org.apache.cassandra.service.GCInspector
 
instance - Static variable in class org.apache.cassandra.service.StorageLoadBalancer
 
instance - Static variable in class org.apache.cassandra.service.StorageProxy
 
instance - Static variable in class org.apache.cassandra.service.StorageService
 
instance - Static variable in class org.apache.cassandra.streaming.StreamingService
 
InstrumentingCache<K,V> - Class in org.apache.cassandra.cache
Wraps an ICache in requests + hits tracking.
InstrumentingCache(ICache<K, V>, String, String) - Constructor for class org.apache.cassandra.cache.InstrumentingCache
 
InstrumentingCacheMBean - Interface in org.apache.cassandra.cache
 
INTEGER - Static variable in class org.apache.cassandra.cql.CqlLexer
 
INTEGER - Static variable in class org.apache.cassandra.cql.CqlParser
 
IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
IntegerNegativeLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
IntegerPositiveLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
IntegerType - Class in org.apache.cassandra.db.marshal
 
internedNames - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
InterNode - Interface in org.apache.cassandra
 
internode_encryption - Variable in class org.apache.cassandra.config.EncryptionOptions
 
internOrCopy(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
interpret(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
interpret(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by any entity wanting to interrogate the status of an endpoint.
intersect(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
this = this AND other
intersectionCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of the intersection of the two sets.
intersectionWith(Range) - Method in class org.apache.cassandra.dht.Range
 
intersects(Range) - Method in class org.apache.cassandra.dht.Range
 
intersects(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
returns true if the sets have any elements in common
intervalInMillis - Static variable in class org.apache.cassandra.gms.Gossiper
 
intSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
invalidate(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Invalidates the ranges containing the given token.
invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateCachedRow(DecoratedKey) - Method in class org.apache.cassandra.io.CompactionController
 
invalidateCachedTokenEndpointValues() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
invalidateCaches() - Method in class org.apache.cassandra.locator.TokenMetadata
 
invalidateKeyCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateKeyCache() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
invalidate the key cache; for use after invalidating row cache
invalidateKeyCaches(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
invalidateKeyCaches(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
invalidateKeyCaches(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
invalidateRowCache() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
invalidateRowCache() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
invalidate the row cache; for use after bulk loading via BinaryMemtable
invalidateRowCaches(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
invalidateRowCaches(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
invalidateRowCaches(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
invalids() - Method in class org.apache.cassandra.utils.MerkleTree
Returns a lazy iterator of invalid TreeRanges that need to be filled in order to make the given Range valid.
InvalidUrlException - Exception in org.apache.cassandra.cql.jdbc
Runtime exception handling during incorrect connection url provided.
InvalidUrlException(String) - Constructor for exception org.apache.cassandra.cql.jdbc.InvalidUrlException
Constructor using fields.
invokeAll(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Executes the given tasks, returning a list of Futures holding their status and results when all complete.
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Executes the given tasks, returning a list of Futures holding their status and results when all complete or the timeout expires, whichever happens first.
invokeAny(Collection<? extends Callable<T>>) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Executes the given tasks, returning the result of one that has completed successfully (i.e., without throwing an exception), if any do.
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Executes the given tasks, returning the result of one that has completed successfully (i.e., without throwing an exception), if any do before the given timeout elapses.
IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
IP_ADDRESS - Static variable in class org.apache.cassandra.cli.CliParser
 
ip_address() - Method in class org.apache.cassandra.cli.CliParser
 
IPartitioner<T extends Token> - Interface in org.apache.cassandra.dht
 
IReadCommand - Interface in org.apache.cassandra.service
 
IRequestScheduler - Interface in org.apache.cassandra.scheduler
Implementors of IRequestScheduler must provide a constructor taking a RequestSchedulerOptions object.
IResponseResolver<T> - Interface in org.apache.cassandra.service
 
IRowCacheProvider - Interface in org.apache.cassandra.cache
Provides cache objects with a requested capacity.
isAfterLast() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
isAlive() - Method in class org.apache.cassandra.gms.EndpointState
 
isAlive(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
isAlive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
Failure Detector's knowledge of whether a node is up or down.
isAutoBootstrap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isBeforeFirst() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
 
isBootstrapped() - Static method in class org.apache.cassandra.db.SystemTable
 
isCapacitySetManually() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.BytesType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.LongType
 
isCaseSensitive() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
isClean() - Method in class org.apache.cassandra.db.BinaryMemtable
 
isClean() - Method in class org.apache.cassandra.db.Memtable
 
isClientMode() - Method in class org.apache.cassandra.service.StorageService
 
isClosed() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
isColumn() - Method in class org.apache.cassandra.cql.Relation
 
isColumnList() - Method in class org.apache.cassandra.cql.SelectExpression
 
isColumnRange() - Method in class org.apache.cassandra.cql.SelectExpression
 
isColumnRange() - Method in class org.apache.cassandra.cql.SelectStatement
 
isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectExpression
 
isColumnsReversed() - Method in class org.apache.cassandra.cql.SelectStatement
 
isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
isCommutative() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCompressed_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
isConnected() - Static method in class org.apache.cassandra.cli.CliMain
Checks whether the thrift client is connected.
isCountOperation() - Method in class org.apache.cassandra.cql.SelectStatement
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.BytesType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.LongType
 
isCurrency() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
isDataPresent() - Method in interface org.apache.cassandra.service.IResponseResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RowDigestResolver
 
isDataPresent() - Method in class org.apache.cassandra.service.RowRepairResolver
 
isDelta() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadResponse
 
isDropped() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isEmpty() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
isEmpty() - Method in class org.apache.cassandra.cache.SerializingCache
 
isEmpty() - Method in class org.apache.cassandra.db.ColumnFamily
 
isEmpty() - Method in class org.apache.cassandra.db.DecoratedKey
 
isEmpty() - Method in class org.apache.cassandra.db.RowMutation
 
isEmpty() - Method in class org.apache.cassandra.io.AbstractCompactedRow
 
isEmpty() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
isEmpty() - Method in class org.apache.cassandra.io.PrecompactedRow
 
isEmpty() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
isEmpty() - Method in class org.apache.cassandra.utils.ExpiringMap
 
isEmpty() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns true if there are no set bits
isEnabled() - Method in class org.apache.cassandra.gms.Gossiper
 
isEOF() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
isEOF() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
isEOF() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
isEqual(SSTableIdentityIterator, SSTableIdentityIterator) - Method in class org.apache.cassandra.io.CompactionIterator
 
isEqual(T1, T1) - Method in class org.apache.cassandra.utils.ReducingIterator
override this if the keys you want to base the reduce on are not the same as the object itself (but can be generated from it)
isExists(String) - Static method in class org.apache.cassandra.io.util.FileUtils
 
isExpired() - Method in class org.apache.cassandra.db.Memtable
 
isFirst() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
isFromTheFuture() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
isHintedHandoffEnabled() - Static method in class org.apache.cassandra.service.StorageProxy
 
isIndex() - Method in class org.apache.cassandra.db.ColumnFamilyStore
true if this CFS contains secondary index data
isIndexBuilt() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Check if index is already built for current store
isIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
isInitialized() - Method in class org.apache.cassandra.service.StorageService
 
isInitialized() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isInitialized() - Method in class org.apache.cassandra.tools.NodeProbe
 
isInvalid() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
isJoined() - Method in class org.apache.cassandra.service.StorageService
 
isJoined() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isJoined() - Method in class org.apache.cassandra.tools.NodeProbe
 
isKey() - Method in class org.apache.cassandra.cql.Relation
 
isKeyInRemainingSSTables(DecoratedKey, Set<? extends SSTable>) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Uses bloom filters to check if key may be present in any sstable in this ColumnFamilyStore, minus a set of provided ones.
isKeyList() - Method in class org.apache.cassandra.cql.WhereClause
 
isKeyRange() - Method in class org.apache.cassandra.cql.SelectStatement
 
isKeyRange() - Method in class org.apache.cassandra.cql.WhereClause
 
isKnownEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
 
isLast() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
isLatencyForSnitch() - Method in interface org.apache.cassandra.net.IMessageCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.AsyncRepairCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.ReadCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.RepairCallback
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
isLatencyForSnitch() - Method in class org.apache.cassandra.service.WriteResponseHandler
 
isLatestVersion - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
isLeaving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isLegalName(String) - Static method in class org.apache.cassandra.db.migration.Migration
 
isLive() - Method in class org.apache.cassandra.db.Column
 
isLive() - Method in interface org.apache.cassandra.db.IColumn
For a simple column, live == !isMarkedForDelete.
isLive() - Method in class org.apache.cassandra.db.SuperColumn
 
isLocalId() - Method in class org.apache.cassandra.utils.NodeId
 
isMajor - Variable in class org.apache.cassandra.io.CompactionController
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.Column
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.DeletedColumn
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.ExpiringColumn
 
isMarkedForDelete() - Method in interface org.apache.cassandra.db.IColumn
 
isMarkedForDelete() - Method in interface org.apache.cassandra.db.IColumnContainer
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.SuperColumn
 
isMember(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isModified() - Method in class org.apache.cassandra.utils.DefaultDouble
 
isModified() - Method in class org.apache.cassandra.utils.DefaultInteger
 
isMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isOverflowed() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.Filter
 
isPresent(ByteBuffer) - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
isPutCopying() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
isPutCopying() - Method in interface org.apache.cassandra.cache.ICache
 
isPutCopying() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
isPutCopying() - Method in class org.apache.cassandra.cache.SerializingCache
 
isRelevant(IColumn, IColumnContainer, int) - Static method in class org.apache.cassandra.db.filter.QueryFilter
 
isRPCServerRunning() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Returns whether the underlying RPC server is running or not.
isRPCServerRunning() - Method in interface org.apache.cassandra.service.CassandraDaemon
 
isRPCServerRunning() - Method in class org.apache.cassandra.service.StorageService
 
isRPCServerRunning() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
isRunning - Variable in class org.apache.cassandra.service.AbstractCassandraDaemon
 
isSetConsistencyLevel() - Method in class org.apache.cassandra.cql.UpdateStatement
True if an explicit consistency level was parsed from the statement.
isShutdown() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Returns true if this executor has been shut down.
isShutdown() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
isSignaled() - Method in class org.apache.cassandra.utils.SimpleCondition
 
isSigned() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.BytesType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.LongType
 
isSigned() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isStreamingMode_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
isSuccess() - Method in class org.apache.cassandra.db.WriteResponse
 
isSuper() - Method in class org.apache.cassandra.db.ColumnFamily
 
isTerminated() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
isTokenInRanges(Token, Iterable<Range>) - Static method in class org.apache.cassandra.dht.Range
 
isWildcard() - Method in class org.apache.cassandra.cql.SelectExpression
 
isWildcard() - Method in class org.apache.cassandra.cql.SelectStatement
 
isWrapAround(Token, Token) - Static method in class org.apache.cassandra.dht.Range
Tells if the given range is a wrap around.
isWrapAround() - Method in class org.apache.cassandra.dht.Range
 
isWrapperFor(Class<?>) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
iterator() - Method in class org.apache.cassandra.db.ColumnFamily
 
iterator() - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
iterator - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
iterator(long, int) - Method in class org.apache.cassandra.io.util.SegmentedFile
 
iterator() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
iterator() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
iterator() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRangeIterator
 
iterator() - Method in class org.apache.cassandra.utils.ReducingIterator
 
IVerbHandler - Interface in org.apache.cassandra.net
IVerbHandler provides the method that all verb handlers need to implement.
IWriteResponseHandler - Interface in org.apache.cassandra.service
 

J

J - Static variable in class org.apache.cassandra.cql.CqlLexer
 
J - Static variable in class org.apache.cassandra.cql.CqlParser
 
jdbcCompliant() - Method in class org.apache.cassandra.cql.jdbc.CassandraDriver
Returns true, if it is jdbc compliant.
JMXConfigurableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
 
JMXConfigurableThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutor
 
JMXConfigurableThreadPoolExecutorMBean - Interface in org.apache.cassandra.concurrent
 
JMXEnabledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This is a wrapper class for the ScheduledThreadPoolExecutor.
JMXEnabledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(int, long, TimeUnit, BlockingQueue<Runnable>, NamedThreadFactory, String) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutor(Stage) - Constructor for class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
JMXEnabledThreadPoolExecutorMBean - Interface in org.apache.cassandra.concurrent
 
jmxPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
job_jar_file_location - Variable in class org.apache.cassandra.config.Config
 
job_tracker_host - Variable in class org.apache.cassandra.config.Config
 
joinRing() - Method in class org.apache.cassandra.service.StorageService
 
joinRing() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
joinRing() - Method in class org.apache.cassandra.tools.NodeProbe
 

K

K - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_AND - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_AND - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_APPLY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_APPLY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_BATCH - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_BATCH - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_BEGIN - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_BEGIN - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_COLUMNFAMILY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_COLUMNFAMILY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_CONSISTENCY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_CONSISTENCY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_COUNT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_COUNT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_CREATE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_CREATE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_DELETE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_DELETE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_DROP - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_DROP - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_FIRST - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_FIRST - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_FROM - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_FROM - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_IN - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_IN - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_INDEX - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_INDEX - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_INSERT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_INSERT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_INTO - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_INTO - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_KEY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_KEY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_KEYSPACE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_KEYSPACE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_LEVEL - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_LEVEL - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_LIMIT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_LIMIT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_ON - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_ON - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_PRIMARY - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_PRIMARY - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_REVERSED - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_REVERSED - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_SELECT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_SELECT - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_SET - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_SET - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_TRUNCATE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_TRUNCATE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_UPDATE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_UPDATE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_USE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_USE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_USING - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_USING - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_VALUES - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_VALUES - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_WHERE - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_WHERE - Static variable in class org.apache.cassandra.cql.CqlParser
 
K_WITH - Static variable in class org.apache.cassandra.cql.CqlLexer
 
K_WITH - Static variable in class org.apache.cassandra.cql.CqlParser
 
KEEPALIVE - Static variable in class org.apache.cassandra.concurrent.StageManager
 
key - Variable in class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
key() - Method in class org.apache.cassandra.db.CounterMutation
 
key - Variable in class org.apache.cassandra.db.DecoratedKey
 
key - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
key() - Method in interface org.apache.cassandra.db.IMutation
 
key - Variable in class org.apache.cassandra.db.ReadCommand
 
key - Variable in class org.apache.cassandra.db.Row
 
key() - Method in class org.apache.cassandra.db.RowMutation
 
key() - Method in class org.apache.cassandra.db.WriteResponse
 
key - Variable in class org.apache.cassandra.io.AbstractCompactedRow
 
key - Variable in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
key - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
key_alias - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
key_cache_save_period_in_seconds - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
key_cache_size - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
key_validation_class - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
keyAlias(ByteBuffer) - Method in class org.apache.cassandra.config.CFMetaData
 
keyCache - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
keyCacheSavePeriod(int) - Method in class org.apache.cassandra.config.CFMetaData
 
keyCacheSize(double) - Method in class org.apache.cassandra.config.CFMetaData
 
KeyIterator - Class in org.apache.cassandra.io.sstable
 
KeyIterator(Descriptor) - Constructor for class org.apache.cassandra.io.sstable.KeyIterator
 
keyRangeExpr() - Method in class org.apache.cassandra.cli.CliParser
 
keySamples(Range) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
keySet() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
keySet() - Method in interface org.apache.cassandra.cache.ICache
 
keySet() - Method in class org.apache.cassandra.cache.SerializingCache
 
keySet() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
keySet() - Method in class org.apache.cassandra.utils.ExpiringMap
 
KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
keyspace() - Method in class org.apache.cassandra.cli.CliParser
 
keyspace - Variable in class org.apache.cassandra.cli.CliSessionState
 
keyspace - Variable in class org.apache.cassandra.db.IndexScanCommand
 
keyspace - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
keyspace - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
keyspace - Variable in class org.apache.cassandra.db.TruncateResponse
 
keyspace - Variable in class org.apache.cassandra.db.Truncation
 
keyspaceNewName() - Method in class org.apache.cassandra.cli.CliParser
 
KeyspaceNotDefinedException - Exception in org.apache.cassandra.db
 
KeyspaceNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.KeyspaceNotDefinedException
 
KEYSPACES - Static variable in class org.apache.cassandra.auth.Resources
 
KEYSPACES - Static variable in class org.apache.cassandra.cli.CliLexer
 
KEYSPACES - Static variable in class org.apache.cassandra.cli.CliParser
 
KEYSPACES_WRITE_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthority
 
keystore - Variable in class org.apache.cassandra.config.EncryptionOptions
 
keystore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
keyValidator(AbstractType) - Method in class org.apache.cassandra.config.CFMetaData
 
keyValuePair() - Method in class org.apache.cassandra.cli.CliParser
 
keyValuePairExpr() - Method in class org.apache.cassandra.cli.CliParser
 
ks - Variable in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
KsDef - Class in org.apache.cassandra.db.migration.avro
 
KsDef() - Constructor for class org.apache.cassandra.db.migration.avro.KsDef
 
KSMetaData - Class in org.apache.cassandra.config
 
KSMetaData(String, Class<? extends AbstractReplicationStrategy>, Map<String, String>, CFMetaData...) - Constructor for class org.apache.cassandra.config.KSMetaData
 
ksName - Variable in class org.apache.cassandra.config.CFMetaData
 
ksname - Variable in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
ksname - Variable in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
ksname - Variable in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
ksname - Variable in class org.apache.cassandra.io.sstable.Descriptor
 

L

L - Static variable in class org.apache.cassandra.cql.CqlLexer
 
L - Static variable in class org.apache.cassandra.cql.CqlParser
 
LA(int) - Method in class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
 
last() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
last - Variable in class org.apache.cassandra.utils.ReducingIterator
 
LAST_MIGRATION_KEY - Static variable in class org.apache.cassandra.db.migration.Migration
 
lastIndexOf(ByteBuffer, byte, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
ByteBuffer adaptation of org.apache.commons.lang.ArrayUtils.lastIndexOf method
lastKey() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
lastName - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
lastVersion - Variable in class org.apache.cassandra.db.migration.Migration
 
LatencyTracker - Class in org.apache.cassandra.utils
 
LatencyTracker() - Constructor for class org.apache.cassandra.utils.LatencyTracker
 
LazilyCompactedRow - Class in org.apache.cassandra.io
LazilyCompactedRow only computes the row bloom filter and column index in memory (at construction time); it does this by reading one column at a time from each of the rows being compacted, and merging them as it does so.
LazilyCompactedRow(CompactionController, List<SSTableIdentityIterator>) - Constructor for class org.apache.cassandra.io.LazilyCompactedRow
 
leaving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.dht.AbstractBounds
 
left(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
left - Variable in class org.apache.cassandra.utils.Pair
 
LEGACY_VERSION - Static variable in class org.apache.cassandra.io.sstable.Descriptor
 
LegacyBloomFilter - Class in org.apache.cassandra.utils
 
length() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
length() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
length() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
length - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
LENGTH - Static variable in class org.apache.cassandra.utils.NodeId
 
length() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
Letter - Static variable in class org.apache.cassandra.cli.CliLexer
 
Letter - Static variable in class org.apache.cassandra.cli.CliParser
 
LETTER - Static variable in class org.apache.cassandra.cql.CqlLexer
 
LETTER - Static variable in class org.apache.cassandra.cql.CqlParser
 
LexicalUUIDType - Class in org.apache.cassandra.db.marshal
 
LIMIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
LIMIT - Static variable in class org.apache.cassandra.cli.CliParser
 
LIST - Static variable in class org.apache.cassandra.cli.CliLexer
 
LIST - Static variable in class org.apache.cassandra.cli.CliParser
 
listen(InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Listen on the specified port.
listen_address - Variable in class org.apache.cassandra.config.Config
 
listenAddr - Variable in class org.apache.cassandra.service.AbstractCassandraDaemon
 
listEndpointsPendingHints() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
listEndpointsPendingHints() - Method in interface org.apache.cassandra.db.HintedHandOffManagerMBean
List all the endpoints that this node has hints for.
listenPort - Variable in class org.apache.cassandra.service.AbstractCassandraDaemon
 
listStatement() - Method in class org.apache.cassandra.cli.CliParser
 
load(double) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
loadFromStorage(UUID) - Static method in class org.apache.cassandra.db.DefsTable
loads a version of keyspace definitions from storage
loadSchemas() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
load keyspace (table) definitions, but do not initialize the table instances.
loadTokens() - Static method in class org.apache.cassandra.db.SystemTable
Return a map of stored tokens to IP addresses
LocalByPartionerType<T extends Token> - Class in org.apache.cassandra.db.marshal
for sorting columns representing row keys in the row ordering as determined by a partitioner.
LocalByPartionerType(IPartitioner<T>) - Constructor for class org.apache.cassandra.db.marshal.LocalByPartionerType
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.Column
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CounterColumn
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.DeletedColumn
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.ExpiringColumn
 
localCopy(ColumnFamilyStore) - Method in interface org.apache.cassandra.db.IColumn
clones the column, interning column names and making copies of other underlying byte buffers
localCopy() - Method in class org.apache.cassandra.db.RowMutation
 
localCopy(ColumnFamilyStore) - Method in class org.apache.cassandra.db.SuperColumn
 
localFile - Variable in class org.apache.cassandra.streaming.IncomingStreamReader
 
LocalPartitioner - Class in org.apache.cassandra.dht
 
LocalPartitioner(AbstractType) - Constructor for class org.apache.cassandra.dht.LocalPartitioner
 
LocalStrategy - Class in org.apache.cassandra.locator
 
LocalStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.LocalStrategy
 
LocalToken - Class in org.apache.cassandra.dht
 
LocalToken(AbstractType, ByteBuffer) - Constructor for class org.apache.cassandra.dht.LocalToken
 
log() - Static method in class org.apache.cassandra.utils.StatusLogger
 
logExceptionsAfterExecute(Runnable, Throwable) - Static method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
logger - Static variable in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
logger - Static variable in class org.apache.cassandra.db.migration.Migration
 
logger - Static variable in class org.apache.cassandra.gms.EndpointState
 
logger - Static variable in class org.apache.cassandra.locator.Ec2Snitch
 
logger - Static variable in class org.apache.cassandra.service.AbstractRowResolver
 
logger - Static variable in class org.apache.cassandra.service.ReadCallback
 
logger - Static variable in class org.apache.cassandra.service.TruncateResponseHandler
 
logger - Static variable in class org.apache.cassandra.service.WriteResponseHandler
 
login(Map<? extends CharSequence, ? extends CharSequence>) - Method in class org.apache.cassandra.service.ClientState
Attempts to login this client with the given credentials map.
login(AuthenticationRequest) - Method in class org.apache.cassandra.thrift.CassandraServer
 
logout() - Method in class org.apache.cassandra.service.ClientState
 
longSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
LongType - Class in org.apache.cassandra.db.marshal
 
ltree - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 

M

M - Static variable in class org.apache.cassandra.cql.CqlLexer
 
M - Static variable in class org.apache.cassandra.cql.CqlParser
 
mA() - Method in class org.apache.cassandra.cql.CqlLexer
 
main(String[]) - Static method in class org.apache.cassandra.cli.CliMain
 
main(String[]) - Static method in class org.apache.cassandra.gms.FailureDetector
 
main(String[]) - Static method in class org.apache.cassandra.thrift.CassandraDaemon
 
main(String[]) - Static method in class org.apache.cassandra.tools.GetVersion
 
main(String[]) - Static method in class org.apache.cassandra.tools.NodeCmd
 
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableExport
Given arguments specifying an SSTable, and optionally an output file, export the contents of the SSTable to JSON.
main(String[]) - Static method in class org.apache.cassandra.tools.SSTableImport
Converts JSON to an SSTable file.
makeColumns(Message) - Static method in class org.apache.cassandra.service.MigrationManager
 
makeCombinedName(String, String) - Static method in class org.apache.cassandra.db.HintedHandOffManager
 
makeCql() - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
applies current bindings to produce a string that can be sent to the server.
makeMutationMessage(int) - Method in class org.apache.cassandra.db.CounterMutation
 
makeReplicationMutation() - Method in class org.apache.cassandra.db.CounterMutation
 
makeRowMutationMessage(StorageService.Verb, int) - Method in class org.apache.cassandra.db.RowMutation
 
makeTruncateResponseMessage(Message, TruncateResponse) - Static method in class org.apache.cassandra.db.TruncateResponse
 
makeType1UUIDFromHost(InetAddress) - Static method in class org.apache.cassandra.utils.UUIDGen
Creates a type 1 UUID (time-based UUID) that substitutes a hash of an IP address in place of the MAC (unavailable to Java).
makeWriteResponseMessage(Message, WriteResponse) - Static method in class org.apache.cassandra.db.WriteResponse
 
mAlnum() - Method in class org.apache.cassandra.cli.CliLexer
 
mAND() - Method in class org.apache.cassandra.cli.CliLexer
 
map(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
adds this cfm to the map.
mAPI_VERSION() - Method in class org.apache.cassandra.cli.CliLexer
 
MappedFileDataInput - Class in org.apache.cassandra.io.util
 
MappedFileDataInput(FileInputStream, String, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
MappedFileDataInput(MappedByteBuffer, String, int) - Constructor for class org.apache.cassandra.io.util.MappedFileDataInput
 
mark() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
mark() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
mark() - Method in interface org.apache.cassandra.io.util.FileDataInput
 
mark() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
markCompacted(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
 
markCompacted() - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
markCompacting(Collection<SSTableReader>, int, int) - Method in class org.apache.cassandra.db.DataTracker
 
markForDeleteAt(int, long) - Method in class org.apache.cassandra.db.SuperColumn
Deprecated. 
markSupported() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
MarshalException - Exception in org.apache.cassandra.db.marshal
 
MarshalException(String) - Constructor for exception org.apache.cassandra.db.marshal.MarshalException
 
MarshalException(String, Throwable) - Constructor for exception org.apache.cassandra.db.marshal.MarshalException
 
mASSUME() - Method in class org.apache.cassandra.cli.CliLexer
 
max() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
MAX_COLUMNS_DEFAULT - Static variable in class org.apache.cassandra.cql.SelectExpression
 
max_compaction_threshold - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
MAX_CONNECT_ATTEMPTS - Static variable in class org.apache.cassandra.streaming.FileStreamTask
 
max_hint_window_in_ms - Variable in class org.apache.cassandra.config.Config
 
max_keys - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
MAX_NAME_LENGTH - Static variable in interface org.apache.cassandra.db.IColumn
 
MAX_RETRIES - Static variable in class org.apache.cassandra.io.DeletionService
 
MAX_SEGMENT_SIZE - Static variable in class org.apache.cassandra.io.util.MmappedSegmentedFile
 
MAX_UNSIGNED_SHORT - Static variable in class org.apache.cassandra.utils.FBUtilities
 
maxCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
 
maxDataAge - Variable in class org.apache.cassandra.io.sstable.SSTableReader
maxDataAge is a timestamp in local server time (e.g.
maxsize() - Method in class org.apache.cassandra.utils.MerkleTree
 
maxsize(long) - Method in class org.apache.cassandra.utils.MerkleTree
 
maybeAddEntry(DecoratedKey, long) - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
maybeAddLatency(IMessageCallback, InetAddress, double) - Method in class org.apache.cassandra.net.MessagingService
Track latency information for the dynamic snitch
maybeInitializeLocalState(int) - Method in class org.apache.cassandra.gms.Gossiper
 
maybeIntern(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
maybeLoad() - Static method in class org.apache.cassandra.utils.Mx4jTool
Starts a JMX over http interface if and mx4j-tools.jar is in the classpath.
maybeRenew(CounterColumn) - Method in class org.apache.cassandra.utils.NodeId.OneShotRenewer
 
maybeResolveForRepair() - Method in class org.apache.cassandra.service.ReadCallback
Check digests in the background on the Repair stage if we've received replies too all the requests we sent.
maybeScheduleRepairs(ColumnFamily, String, DecoratedKey, List<ColumnFamily>, List<InetAddress>) - Static method in class org.apache.cassandra.service.RowRepairResolver
For each row version, compare with resolved (the superset of all row versions); if it is missing anything, send a mutation to the endpoint it come from.
mB() - Method in class org.apache.cassandra.cql.CqlLexer
 
MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.db.CompactionManager
 
MBEAN_OBJECT_NAME - Static variable in class org.apache.cassandra.streaming.StreamingService
 
mBY() - Method in class org.apache.cassandra.cli.CliLexer
 
mC() - Method in class org.apache.cassandra.cql.CqlLexer
 
mCharacterEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOLUMN() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOMMENT() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOMMENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mCOMPIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mCONFIG() - Method in class org.apache.cassandra.cli.CliLexer
 
mCONNECT() - Method in class org.apache.cassandra.cli.CliLexer
 
mCONSISTENCYLEVEL() - Method in class org.apache.cassandra.cli.CliLexer
 
mCOUNT() - Method in class org.apache.cassandra.cli.CliLexer
 
mCREATE() - Method in class org.apache.cassandra.cli.CliLexer
 
mD() - Method in class org.apache.cassandra.cql.CqlLexer
 
mDecimalDigit() - Method in class org.apache.cassandra.cli.CliLexer
 
mDECR() - Method in class org.apache.cassandra.cli.CliLexer
 
mDEL() - Method in class org.apache.cassandra.cli.CliLexer
 
mDESCRIBE() - Method in class org.apache.cassandra.cli.CliLexer
 
mDigit() - Method in class org.apache.cassandra.cli.CliLexer
 
mDIGIT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mDoubleLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
mDROP() - Method in class org.apache.cassandra.cli.CliLexer
 
mE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mean() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
mean() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
memOps(double) - Method in class org.apache.cassandra.config.CFMetaData
 
MemoryInputStream - Class in org.apache.cassandra.io.util
 
MemoryInputStream(FreeableMemory) - Constructor for class org.apache.cassandra.io.util.MemoryInputStream
 
MemoryOutputStream - Class in org.apache.cassandra.io.util
This class provides a way to stream the writes into the Memory
MemoryOutputStream(Memory) - Constructor for class org.apache.cassandra.io.util.MemoryOutputStream
 
memSize(int) - Method in class org.apache.cassandra.config.CFMetaData
 
Memtable - Class in org.apache.cassandra.db
 
Memtable(ColumnFamilyStore) - Constructor for class org.apache.cassandra.db.Memtable
 
memtable_flush_after_mins - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
memtable_flush_queue_size - Variable in class org.apache.cassandra.config.Config
 
memtable_flush_writers - Variable in class org.apache.cassandra.config.Config
 
memtable_operations_in_millions - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
memtable_throughput_in_mb - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
memtable_total_space_in_mb - Variable in class org.apache.cassandra.config.Config
 
MemtableAllocator - Class in org.apache.cassandra.db
A memstore-local allocation buffer.
MemtableAllocator() - Constructor for class org.apache.cassandra.db.MemtableAllocator
 
memTime(int) - Method in class org.apache.cassandra.config.CFMetaData
 
merge(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Return a context w/ an aggregated count for each node id.
merge(ByteBuffer, ByteBuffer) - Method in interface org.apache.cassandra.db.context.IContext
Return a context w/ an aggregated count for each node id.
merge_shards_chance - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
mergeShardsChance(double) - Method in class org.apache.cassandra.config.CFMetaData
 
MerkleTree - Class in org.apache.cassandra.utils
A MerkleTree implemented as a binary tree.
MerkleTree(IPartitioner, Range, byte, long) - Constructor for class org.apache.cassandra.utils.MerkleTree
 
MerkleTree.MerkleTreeSerializer - Class in org.apache.cassandra.utils
 
MerkleTree.MerkleTreeSerializer() - Constructor for class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
MerkleTree.RowHash - Class in org.apache.cassandra.utils
Hash value representing a row, to be used to pass hashes to the MerkleTree.
MerkleTree.RowHash(Token, byte[]) - Constructor for class org.apache.cassandra.utils.MerkleTree.RowHash
 
MerkleTree.TreeRange - Class in org.apache.cassandra.utils
The public interface to a range in the tree.
MerkleTree.TreeRangeIterator - Class in org.apache.cassandra.utils
Returns the leaf (range) of a given tree in increasing order.
mEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
mEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
Message - Class in org.apache.cassandra.net
 
Message(InetAddress, StorageService.Verb, byte[], int) - Constructor for class org.apache.cassandra.net.Message
 
MessageDeliveryTask - Class in org.apache.cassandra.net
 
MessageDeliveryTask(Message, String) - Constructor for class org.apache.cassandra.net.MessageDeliveryTask
 
MessageProducer - Interface in org.apache.cassandra.net
 
MessagingService - Class in org.apache.cassandra.net
 
MessagingServiceMBean - Interface in org.apache.cassandra.net
MBean exposing MessagingService metrics.
metadata() - Method in class org.apache.cassandra.db.ColumnFamily
 
metadata - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
metadata - Variable in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
metadata - Variable in class org.apache.cassandra.io.sstable.SSTable
 
mEXIT() - Method in class org.apache.cassandra.cli.CliLexer
 
mF() - Method in class org.apache.cassandra.cql.CqlLexer
 
mFAMILY() - Method in class org.apache.cassandra.cli.CliLexer
 
mFILE() - Method in class org.apache.cassandra.cli.CliLexer
 
mFLOAT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mG() - Method in class org.apache.cassandra.cql.CqlLexer
 
mGET() - Method in class org.apache.cassandra.cli.CliLexer
 
mH() - Method in class org.apache.cassandra.cql.CqlLexer
 
mHELP() - Method in class org.apache.cassandra.cli.CliLexer
 
mHEX() - Method in class org.apache.cassandra.cql.CqlLexer
 
mHexDigit() - Method in class org.apache.cassandra.cli.CliLexer
 
mHexEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
mI() - Method in class org.apache.cassandra.cql.CqlLexer
 
mIDENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mIdentifier() - Method in class org.apache.cassandra.cli.CliLexer
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
midpoint(Token, Token) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate a Token representing the approximate "middle" of the given range.
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.LocalPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
midpoint(Token, Token) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
midpoint(BigInteger, BigInteger, int) - Static method in class org.apache.cassandra.utils.FBUtilities
Given two bit arrays represented as BigIntegers, containing the given number of significant bits, calculate a midpoint.
Migration - Class in org.apache.cassandra.db.migration.avro
 
Migration() - Constructor for class org.apache.cassandra.db.migration.avro.Migration
 
migration - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
Migration - Class in org.apache.cassandra.db.migration
A migration represents a single metadata mutation (cf dropped, added, etc.).
Migration() - Constructor for class org.apache.cassandra.db.migration.Migration
Subclasses must have a matching constructor
migration(UUID) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
MigrationManager - Class in org.apache.cassandra.service
 
MigrationManager() - Constructor for class org.apache.cassandra.service.MigrationManager
 
MIGRATIONS_CF - Static variable in class org.apache.cassandra.db.migration.Migration
 
MIGRATIONS_KEY - Static variable in class org.apache.cassandra.db.migration.Migration
 
MigrationsCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
min() - Method in class org.apache.cassandra.utils.EstimatedHistogram
 
min_compaction_threshold - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
minCompactionThreshold(int) - Method in class org.apache.cassandra.config.CFMetaData
 
mINCR() - Method in class org.apache.cassandra.cli.CliLexer
 
MINIMUM - Static variable in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
mINTEGER() - Method in class org.apache.cassandra.cql.CqlLexer
 
mIntegerNegativeLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
mIntegerPositiveLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
mIP_ADDRESS() - Method in class org.apache.cassandra.cli.CliLexer
 
mJ() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_AND() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_APPLY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_BATCH() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_BEGIN() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_COLUMNFAMILY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_CONSISTENCY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_COUNT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_CREATE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_DELETE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_DROP() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_FIRST() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_FROM() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_IN() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_INDEX() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_INSERT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_INTO() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_KEY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_KEYSPACE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_LEVEL() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_LIMIT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_ON() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_PRIMARY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_REVERSED() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_SELECT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_SET() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_TRUNCATE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_UPDATE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_USE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_USING() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_VALUES() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_WHERE() - Method in class org.apache.cassandra.cql.CqlLexer
 
mK_WITH() - Method in class org.apache.cassandra.cql.CqlLexer
 
mKEYSPACE() - Method in class org.apache.cassandra.cli.CliLexer
 
mKEYSPACES() - Method in class org.apache.cassandra.cli.CliLexer
 
mL() - Method in class org.apache.cassandra.cql.CqlLexer
 
mLetter() - Method in class org.apache.cassandra.cli.CliLexer
 
mLETTER() - Method in class org.apache.cassandra.cql.CqlLexer
 
mLIMIT() - Method in class org.apache.cassandra.cli.CliLexer
 
mLIST() - Method in class org.apache.cassandra.cli.CliLexer
 
mM() - Method in class org.apache.cassandra.cql.CqlLexer
 
MmappedSegmentedFile - Class in org.apache.cassandra.io.util
 
MmappedSegmentedFile(String, long, SegmentedFile.Segment[]) - Constructor for class org.apache.cassandra.io.util.MmappedSegmentedFile
 
mMULTILINE_COMMENT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mN() - Method in class org.apache.cassandra.cql.CqlLexer
 
mNonEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
mO() - Method in class org.apache.cassandra.cql.CqlLexer
 
modifications_ - Variable in class org.apache.cassandra.db.RowMutation
 
mostRecentLiveChangeAt() - Method in class org.apache.cassandra.db.Column
 
mostRecentLiveChangeAt() - Method in interface org.apache.cassandra.db.IColumn
 
mostRecentLiveChangeAt() - Method in class org.apache.cassandra.db.SuperColumn
 
move(String) - Method in class org.apache.cassandra.service.StorageService
 
move(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
move(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
moveToNext() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
moving(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
mP() - Method in class org.apache.cassandra.cql.CqlLexer
 
mQ() - Method in class org.apache.cassandra.cql.CqlLexer
 
mQUIT() - Method in class org.apache.cassandra.cli.CliLexer
 
mR() - Method in class org.apache.cassandra.cql.CqlLexer
 
mRANGEOP() - Method in class org.apache.cassandra.cql.CqlLexer
 
mS() - Method in class org.apache.cassandra.cql.CqlLexer
 
mSEMICOLON() - Method in class org.apache.cassandra.cli.CliLexer
 
mSET() - Method in class org.apache.cassandra.cli.CliLexer
 
mSHOW() - Method in class org.apache.cassandra.cli.CliLexer
 
mSingleEscapeCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
mSingleStringCharacter() - Method in class org.apache.cassandra.cli.CliLexer
 
mSTRING_LITERAL() - Method in class org.apache.cassandra.cql.CqlLexer
 
mStringLiteral() - Method in class org.apache.cassandra.cli.CliLexer
 
mT() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__100() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__101() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__102() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__103() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__104() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__105() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__106() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__107() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__108() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__109() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__110() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__111() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__112() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__113() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__114() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__115() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__116() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__117() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__75() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__76() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__77() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__78() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__79() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__80() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__81() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__82() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__83() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__84() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__85() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__86() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__87() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__88() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__89() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__90() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__91() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__92() - Method in class org.apache.cassandra.cql.CqlLexer
 
mT__98() - Method in class org.apache.cassandra.cli.CliLexer
 
mT__99() - Method in class org.apache.cassandra.cli.CliLexer
 
mTokens() - Method in class org.apache.cassandra.cli.CliLexer
 
mTokens() - Method in class org.apache.cassandra.cql.CqlLexer
 
mTRUNCATE() - Method in class org.apache.cassandra.cli.CliLexer
 
mTTL() - Method in class org.apache.cassandra.cli.CliLexer
 
mU() - Method in class org.apache.cassandra.cql.CqlLexer
 
multiget_count(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
multiget_slice(List<ByteBuffer>, ColumnParent, SlicePredicate, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql.CqlLexer
 
MULTILINE_COMMENT - Static variable in class org.apache.cassandra.cql.CqlParser
 
mUnicodeEscapeSequence() - Method in class org.apache.cassandra.cli.CliLexer
 
mUPDATE() - Method in class org.apache.cassandra.cli.CliLexer
 
MurmurHash - Class in org.apache.cassandra.utils
This is a very fast, non-cryptographic hash suitable for general hash-based lookup.
MurmurHash() - Constructor for class org.apache.cassandra.utils.MurmurHash
 
mUSE() - Method in class org.apache.cassandra.cli.CliLexer
 
mutate(List<? extends IMutation>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
Use this method to have these Mutations applied across all replicas.
mutateCounter(CounterMutation, String) - Static method in class org.apache.cassandra.service.StorageProxy
Handle counter mutation on the coordinator host.
mUUID() - Method in class org.apache.cassandra.cql.CqlLexer
 
mV() - Method in class org.apache.cassandra.cql.CqlLexer
 
mW() - Method in class org.apache.cassandra.cql.CqlLexer
 
mWITH() - Method in class org.apache.cassandra.cli.CliLexer
 
mWS() - Method in class org.apache.cassandra.cli.CliLexer
 
mWS() - Method in class org.apache.cassandra.cql.CqlLexer
 
mX() - Method in class org.apache.cassandra.cql.CqlLexer
 
Mx4jTool - Class in org.apache.cassandra.utils
If mx4j-tools is in the classpath call maybeLoad to load the HTTP interface of mx4j.
Mx4jTool() - Constructor for class org.apache.cassandra.utils.Mx4jTool
 
mY() - Method in class org.apache.cassandra.cql.CqlLexer
 
mZ() - Method in class org.apache.cassandra.cql.CqlLexer
 

N

n - Variable in class org.apache.cassandra.concurrent.NamedThreadFactory
 
N - Static variable in class org.apache.cassandra.cql.CqlLexer
 
N - Static variable in class org.apache.cassandra.cql.CqlParser
 
name - Variable in class org.apache.cassandra.cli.CliCommandHelp
 
name - Variable in class org.apache.cassandra.config.ColumnDefinition
 
name - Variable in class org.apache.cassandra.config.KSMetaData
 
name - Variable in class org.apache.cassandra.db.Column
 
name() - Method in class org.apache.cassandra.db.Column
 
name - Variable in enum org.apache.cassandra.db.ColumnFamilyStore.CacheType
 
name() - Method in interface org.apache.cassandra.db.IColumn
 
name - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
name - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
name - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
name() - Method in class org.apache.cassandra.db.SuperColumn
 
name - Variable in class org.apache.cassandra.db.Table
 
name() - Method in class org.apache.cassandra.io.sstable.Component
 
NAME_VALIDATOR_REGEX - Static variable in class org.apache.cassandra.db.migration.Migration
 
NamedThreadFactory - Class in org.apache.cassandra.concurrent
This class is an implementation of the ThreadFactory interface.
NamedThreadFactory(String) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
 
NamedThreadFactory(String, int) - Constructor for class org.apache.cassandra.concurrent.NamedThreadFactory
 
NamesQueryFilter - Class in org.apache.cassandra.db.filter
 
NamesQueryFilter(SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter(ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
needDeserialize() - Method in class org.apache.cassandra.io.CompactionController
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.AbstractCommutativeType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.AbstractUUIDType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.AsciiType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.BytesType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.IntegerType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.LongType
 
needsQuotes() - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
needsTaskCommit(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
NetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy takes a property file that gives the intended replication factor in each datacenter.
NetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.NetworkTopologyStrategy
 
new_cfname - Variable in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
new_ksname - Variable in class org.apache.cassandra.db.migration.avro.RenameKeyspace
 
new_version - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
newCacheProvider(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
newIndexedColumnFamily(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
newIndexMetadata(CFMetaData, ColumnDefinition, AbstractType) - Static method in class org.apache.cassandra.config.CFMetaData
 
newKs - Variable in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
newMessageDigest(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newPartitioner(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
newSince(long) - Method in class org.apache.cassandra.io.sstable.SSTableReader
Tests if the sstable contains data newer than the given age param (in localhost currentMilli time).
newThread(Runnable) - Method in class org.apache.cassandra.concurrent.NamedThreadFactory
 
newVersion - Variable in class org.apache.cassandra.db.migration.Migration
 
next() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
next() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
next() - Method in class org.apache.cassandra.db.RowIterator
 
next() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableBoundedScanner
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
next() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
next() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
nextKeyValue() - Method in class org.apache.cassandra.hadoop.ColumnFamilyRecordReader
 
nextSetBit(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the index of the first set bit starting at the index specified.
nextSetBit(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the index of the first set bit starting at the index specified.
nextToken() - Method in class org.apache.cassandra.cql.CqlLexer
 
NODE_ADD_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ADD_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_ADD_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ADD_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_ASSUME - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ASSUME - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_COLUMN_ACCESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_COLUMN_ACCESS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_CONNECT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_CONNECT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_CONSISTENCY_LEVEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_CONSISTENCY_LEVEL - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DEL_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DEL_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DEL_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DEL_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DESCRIBE_CLUSTER - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DESCRIBE_CLUSTER - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_DESCRIBE_TABLE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_DESCRIBE_TABLE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_EXIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_EXIT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_HELP - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_HELP - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_ID_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
NODE_ID_LIST - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_ID_LIST - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_KEY_RANGE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_KEY_RANGE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_LIMIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_LIMIT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_LIST - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_LIST - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_NEW_CF_ACCESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_NEW_CF_ACCESS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_NEW_KEYSPACE_ACCESS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_NEW_KEYSPACE_ACCESS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_NO_OP - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_NO_OP - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_SHOW_CLUSTER_NAME - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SHOW_CLUSTER_NAME - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_SHOW_KEYSPACES - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SHOW_KEYSPACES - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_SHOW_VERSION - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_SHOW_VERSION - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_COUNT - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_COUNT - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_DECR - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_DECR - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_DEL - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_DEL - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_GET - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_GET - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_GET_WITH_CONDITIONS - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_GET_WITH_CONDITIONS - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_INCR - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_INCR - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_THRIFT_SET - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_THRIFT_SET - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_TRUNCATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_TRUNCATE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_UPDATE_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_UPDATE_COLUMN_FAMILY - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_UPDATE_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_UPDATE_KEYSPACE - Static variable in class org.apache.cassandra.cli.CliParser
 
NODE_USE_TABLE - Static variable in class org.apache.cassandra.cli.CliLexer
 
NODE_USE_TABLE - Static variable in class org.apache.cassandra.cli.CliParser
 
NodeCmd - Class in org.apache.cassandra.tools
 
NodeCmd(NodeProbe) - Constructor for class org.apache.cassandra.tools.NodeCmd
 
NodeCmd.NodeCommand - Enum in org.apache.cassandra.tools
 
NodeId - Class in org.apache.cassandra.utils
 
NodeId.NodeIdRecord - Class in org.apache.cassandra.utils
 
NodeId.NodeIdRecord(NodeId) - Constructor for class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
NodeId.NodeIdRecord(NodeId, long) - Constructor for class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
NodeId.OneShotRenewer - Class in org.apache.cassandra.utils
 
NodeId.OneShotRenewer() - Constructor for class org.apache.cassandra.utils.NodeId.OneShotRenewer
 
NodeIdCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
NodeProbe - Class in org.apache.cassandra.tools
JMX client operations for Cassandra.
NodeProbe(String, int, String, String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host, port, username, and password.
NodeProbe(String, int) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and port.
NodeProbe(String) - Constructor for class org.apache.cassandra.tools.NodeProbe
Creates a NodeProbe using the specified JMX host and default port.
NONE - Static variable in enum org.apache.cassandra.auth.Permission
 
NONE - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
NonEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
NonEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
normal(Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
normalize(Collection<? extends AbstractBounds>) - Static method in class org.apache.cassandra.dht.AbstractBounds
 
NoScheduler - Class in org.apache.cassandra.scheduler
This is basically not having a scheduler, the requests are processed as normally would be handled by the JVM.
NoScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.NoScheduler
 
NoScheduler() - Constructor for class org.apache.cassandra.scheduler.NoScheduler
 
numColumnSpecifiers(Tree) - Static method in class org.apache.cassandra.cli.CliCompiler
 

O

O - Static variable in class org.apache.cassandra.cql.CqlLexer
 
O - Static variable in class org.apache.cassandra.cql.CqlParser
 
objectName() - Method in class org.apache.cassandra.cli.CliParser
 
offset - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
old_cfname - Variable in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
old_ksname - Variable in class org.apache.cassandra.db.migration.avro.RenameKeyspace
 
old_version - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
oldKs - Variable in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
OldNetworkTopologyStrategy - Class in org.apache.cassandra.locator
This Replication Strategy returns the nodes responsible for a given key but respects rack awareness.
OldNetworkTopologyStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
onAlive(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
gets called after a this node joins a cluster
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onAlive(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.MigrationManager
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onChange(InetAddress, ApplicationState, VersionedValue) - Method in class org.apache.cassandra.service.StorageService
 
onDead(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onDead(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onJoin(InetAddress, EndpointState) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
Use to inform interested parties about the change in the state for specified endpoint
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.MigrationManager
I'm not going to act here.
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onJoin(InetAddress, EndpointState) - Method in class org.apache.cassandra.service.StorageService
 
onKeyChange() - Method in class org.apache.cassandra.utils.ReducingIterator
Called at the begining of each new key, before any reduce is called.
onRemove(InetAddress) - Method in interface org.apache.cassandra.gms.IEndpointStateChangeSubscriber
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.MigrationManager
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
onRemove(InetAddress) - Method in class org.apache.cassandra.service.StorageService
 
open(String) - Static method in class org.apache.cassandra.db.Table
 
open(Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
open(Descriptor, Set<Component>, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
open(Descriptor, Set<Component>, Set<DecoratedKey>, DataTracker, CFMetaData, IPartitioner) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
OpenBitSet - Class in org.apache.cassandra.utils.obs
An "open" BitSet implementation that allows direct access to the array of words storing the bits.
OpenBitSet(long) - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
Constructs an OpenBitSet large enough to hold numBits.
OpenBitSet() - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
 
OpenBitSet(long[], int) - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
Constructs an OpenBitSet from an existing long[].
OpenBitSet(BitSet) - Constructor for class org.apache.cassandra.utils.obs.OpenBitSet
Contructs an OpenBitset from a BitSet
OperationType - Enum in org.apache.cassandra.streaming
Streaming operation type.
operator() - Method in class org.apache.cassandra.cli.CliParser
 
operator() - Method in class org.apache.cassandra.cql.Relation
 
optsWithRF(Integer) - Static method in class org.apache.cassandra.config.KSMetaData
 
or(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
 
OrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
OrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner
 
org.apache.cassandra - package org.apache.cassandra
 
org.apache.cassandra.auth - package org.apache.cassandra.auth
 
org.apache.cassandra.cache - package org.apache.cassandra.cache
 
org.apache.cassandra.cli - package org.apache.cassandra.cli
 
org.apache.cassandra.client - package org.apache.cassandra.client
 
org.apache.cassandra.concurrent - package org.apache.cassandra.concurrent
 
org.apache.cassandra.config - package org.apache.cassandra.config
 
org.apache.cassandra.cql - package org.apache.cassandra.cql
 
org.apache.cassandra.cql.jdbc - package org.apache.cassandra.cql.jdbc
 
org.apache.cassandra.db - package org.apache.cassandra.db
 
org.apache.cassandra.db.columniterator - package org.apache.cassandra.db.columniterator
 
org.apache.cassandra.db.commitlog - package org.apache.cassandra.db.commitlog
 
org.apache.cassandra.db.context - package org.apache.cassandra.db.context
 
org.apache.cassandra.db.filter - package org.apache.cassandra.db.filter
 
org.apache.cassandra.db.marshal - package org.apache.cassandra.db.marshal
 
org.apache.cassandra.db.migration - package org.apache.cassandra.db.migration
 
org.apache.cassandra.db.migration.avro - package org.apache.cassandra.db.migration.avro
 
org.apache.cassandra.dht - package org.apache.cassandra.dht
 
org.apache.cassandra.gms - package org.apache.cassandra.gms
 
org.apache.cassandra.hadoop - package org.apache.cassandra.hadoop
 
org.apache.cassandra.io - package org.apache.cassandra.io
 
org.apache.cassandra.io.sstable - package org.apache.cassandra.io.sstable
 
org.apache.cassandra.io.util - package org.apache.cassandra.io.util
 
org.apache.cassandra.locator - package org.apache.cassandra.locator
 
org.apache.cassandra.net - package org.apache.cassandra.net
 
org.apache.cassandra.net.io - package org.apache.cassandra.net.io
 
org.apache.cassandra.net.sink - package org.apache.cassandra.net.sink
 
org.apache.cassandra.scheduler - package org.apache.cassandra.scheduler
 
org.apache.cassandra.security - package org.apache.cassandra.security
 
org.apache.cassandra.security.streaming - package org.apache.cassandra.security.streaming
 
org.apache.cassandra.service - package org.apache.cassandra.service
 
org.apache.cassandra.streaming - package org.apache.cassandra.streaming
 
org.apache.cassandra.thrift - package org.apache.cassandra.thrift
 
org.apache.cassandra.tools - package org.apache.cassandra.tools
 
org.apache.cassandra.utils - package org.apache.cassandra.utils
 
org.apache.cassandra.utils.avro - package org.apache.cassandra.utils.avro
 
org.apache.cassandra.utils.obs - package org.apache.cassandra.utils.obs
 
out - Variable in class org.apache.cassandra.cli.CliSessionState
 
OutboundTcpConnection - Class in org.apache.cassandra.net
 
OutboundTcpConnection(InetAddress) - Constructor for class org.apache.cassandra.net.OutboundTcpConnection
 
OutputBuffer - Class in org.apache.cassandra.io.util
Extends ByteArrayOutputStream to minimize copies.
OutputBuffer() - Constructor for class org.apache.cassandra.io.util.OutputBuffer
 
OutputBuffer(int) - Constructor for class org.apache.cassandra.io.util.OutputBuffer
 

P

P - Static variable in class org.apache.cassandra.cql.CqlLexer
 
P - Static variable in class org.apache.cassandra.cql.CqlParser
 
packIt(byte[], boolean, int) - Method in class org.apache.cassandra.net.MessagingService
 
PAIR - Static variable in class org.apache.cassandra.cli.CliLexer
 
PAIR - Static variable in class org.apache.cassandra.cli.CliParser
 
Pair<T1,T2> - Class in org.apache.cassandra.utils
 
Pair(T1, T2) - Constructor for class org.apache.cassandra.utils.Pair
 
parameters - Variable in class org.apache.cassandra.config.SeedProviderDef
 
parseDoubleOrPercent(String) - Static method in class org.apache.cassandra.utils.FBUtilities
Parses a string representing either a fraction, absolute value or percentage.
PARTIALLY_INCONSISTENT - Static variable in class org.apache.cassandra.utils.MerkleTree
 
partitioner - Variable in class org.apache.cassandra.config.Config
 
partitioner - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
partitioner - Variable in class org.apache.cassandra.dht.AbstractBounds
 
partitioner - Variable in class org.apache.cassandra.io.sstable.SSTable
 
partitioner() - Method in class org.apache.cassandra.utils.MerkleTree
 
partitioner(IPartitioner) - Method in class org.apache.cassandra.utils.MerkleTree
TODO: Find another way to use the local partitioner after serialization.
passiveAnnounce() - Method in class org.apache.cassandra.db.migration.Migration
 
passiveAnnounce(UUID) - Static method in class org.apache.cassandra.service.MigrationManager
announce my version passively over gossip
PASSWD_FILENAME_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
password() - Method in class org.apache.cassandra.cli.CliParser
 
password - Variable in class org.apache.cassandra.cli.CliSessionState
 
PASSWORD_KEY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
path - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
path - Variable in class org.apache.cassandra.io.util.SegmentedFile
 
PendingFile - Class in org.apache.cassandra.streaming
Represents portions of a file to be streamed between nodes.
PendingFile(Descriptor, PendingFile) - Constructor for class org.apache.cassandra.streaming.PendingFile
 
PendingFile(SSTable, Descriptor, String, List<Pair<Long, Long>>, OperationType) - Constructor for class org.apache.cassandra.streaming.PendingFile
 
PendingFile.PendingFileSerializer - Class in org.apache.cassandra.streaming
 
PendingFile.PendingFileSerializer() - Constructor for class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
pendingFiles - Variable in class org.apache.cassandra.streaming.StreamHeader
files to add to the session
pendingRangeChanges(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
performCleanup(ColumnFamilyStore, NodeId.OneShotRenewer) - Method in class org.apache.cassandra.db.CompactionManager
 
performMajor(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CompactionManager
 
performScrub(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CompactionManager
 
performWrite(IMutation, ConsistencyLevel, String, StorageProxy.WritePerformer) - Static method in class org.apache.cassandra.service.StorageProxy
Perform the write of a mutation given a WritePerformer.
PeriodicCommitLogExecutorServiceMBean - Interface in org.apache.cassandra.db.commitlog
 
Permission - Enum in org.apache.cassandra.auth
An enum encapsulating the set of possible permissions that an authenticated user can have for a resource.
phi_convict_threshold - Variable in class org.apache.cassandra.config.Config
 
PMODE_PROPERTY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
port() - Method in class org.apache.cassandra.cli.CliParser
 
position - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
position() - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
posix_fadvise(int, int, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
possibleCommitLogFile(String) - Static method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
postFlushExecutor - Static variable in class org.apache.cassandra.db.ColumnFamilyStore
 
PrecompactedRow - Class in org.apache.cassandra.io
PrecompactedRow merges its rows in its constructor in memory.
PrecompactedRow(DecoratedKey, ColumnFamily) - Constructor for class org.apache.cassandra.io.PrecompactedRow
 
PrecompactedRow(CompactionController, List<SSTableIdentityIterator>) - Constructor for class org.apache.cassandra.io.PrecompactedRow
 
predicate - Variable in class org.apache.cassandra.db.IndexScanCommand
 
predicate - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
prepare(ColumnFamilyStore) - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
 
preprocess(Message) - Method in class org.apache.cassandra.service.AbstractRowResolver
 
preprocess(Message) - Method in interface org.apache.cassandra.service.IResponseResolver
 
preprocess(Message) - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
preservesOrder() - Method in class org.apache.cassandra.dht.AbstractByteOrderedPartitioner
 
preservesOrder() - Method in interface org.apache.cassandra.dht.IPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.LocalPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
PRIMARY_INDEX - Static variable in class org.apache.cassandra.io.sstable.Component
 
printBanner() - Method in class org.apache.cassandra.cli.CliClient
 
printColumnFamilyStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printCompactionStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printInfo(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
Write node information.
printNetworkStats(InetAddress, PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printPendingRanges() - Method in class org.apache.cassandra.locator.TokenMetadata
 
printReleaseVersion(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printRemovalStatus(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
printRing(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
Write a textual representation of the Cassandra ring.
printThreadPoolStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeCmd
 
process(String, ClientState) - Static method in class org.apache.cassandra.cql.QueryProcessor
 
processArgs(CliSessionState, String[]) - Method in class org.apache.cassandra.cli.CliOptions
 
processClientMessage(Message, String, InetAddress) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processServerMessage(Message, String) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processStatement(String) - Static method in class org.apache.cassandra.cli.CliMain
 
progress - Variable in class org.apache.cassandra.streaming.PendingFile
 
PropertyFileSnitch - Class in org.apache.cassandra.locator
Used to determine if two IP's are in the same datacenter or on the same rack.
PropertyFileSnitch() - Constructor for class org.apache.cassandra.locator.PropertyFileSnitch
 
PROTOCOL - Static variable in interface org.apache.cassandra.InterNode
 
ProtocolHeader - Class in org.apache.cassandra.net
 
ProtocolHeader() - Constructor for class org.apache.cassandra.net.ProtocolHeader
 
purge(CFMetaData) - Static method in class org.apache.cassandra.config.CFMetaData
used for evicting cf data out of static tracking collections.
purgeIncompatibleHints() - Static method in class org.apache.cassandra.db.SystemTable
 
pushMigrations(UUID, UUID, InetAddress) - Static method in class org.apache.cassandra.service.MigrationManager
pushes migrations from this host to another host
put(K, V) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
put(K, V) - Method in interface org.apache.cassandra.cache.ICache
 
put(K, V) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
put(K, V) - Method in class org.apache.cassandra.cache.SerializingCache
 
put(Object, Object) - Method in class org.apache.cassandra.concurrent.Context
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.CfDef
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.ColumnDef
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.KsDef
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.Migration
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.RenameKeyspace
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
put(int, Object) - Method in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
put(ByteBuffer, IColumn) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
put(K, V) - Method in class org.apache.cassandra.utils.ExpiringMap
 
putAll(Map<? extends ByteBuffer, ? extends IColumn>) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
putColumn(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 

Q

Q - Static variable in class org.apache.cassandra.cql.CqlLexer
 
Q - Static variable in class org.apache.cassandra.cql.CqlParser
 
QUARANTINE_DELAY - Static variable in class org.apache.cassandra.gms.Gossiper
 
query() - Method in class org.apache.cassandra.cql.CqlParser
 
QueryFilter - Class in org.apache.cassandra.db.filter
 
QueryFilter(DecoratedKey, QueryPath, IFilter) - Constructor for class org.apache.cassandra.db.filter.QueryFilter
 
QueryPath - Class in org.apache.cassandra.db.filter
 
QueryPath(String, ByteBuffer, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.QueryPath
 
QueryPath(ColumnParent) - Constructor for class org.apache.cassandra.db.filter.QueryPath
 
QueryPath(String, ByteBuffer) - Constructor for class org.apache.cassandra.db.filter.QueryPath
 
QueryPath(String) - Constructor for class org.apache.cassandra.db.filter.QueryPath
 
QueryPath(ColumnPath) - Constructor for class org.apache.cassandra.db.filter.QueryPath
 
queryPath - Variable in class org.apache.cassandra.db.ReadCommand
 
QueryProcessor - Class in org.apache.cassandra.cql
 
QueryProcessor() - Constructor for class org.apache.cassandra.cql.QueryProcessor
 
queue(Thread, String) - Method in interface org.apache.cassandra.scheduler.IRequestScheduler
Queue incoming request threads
queue(Thread, String) - Method in class org.apache.cassandra.scheduler.NoScheduler
 
queue(Thread, String) - Method in class org.apache.cassandra.scheduler.RoundRobinScheduler
 
QUEUE_SIZE - Static variable in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat
 
QUIT - Static variable in class org.apache.cassandra.cli.CliLexer
 
QUIT - Static variable in class org.apache.cassandra.cli.CliParser
 

R

R - Static variable in class org.apache.cassandra.cql.CqlLexer
 
R - Static variable in class org.apache.cassandra.cql.CqlParser
 
rack(String) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
RackInferringSnitch - Class in org.apache.cassandra.locator
A simple endpoint snitch implementation that assumes datacenter and rack information is encoded in the 2nd and 3rd octets of the ip address, respectively.
RackInferringSnitch() - Constructor for class org.apache.cassandra.locator.RackInferringSnitch
 
RandomPartitioner - Class in org.apache.cassandra.dht
This class generates a BigIntegerToken using MD5 hash.
RandomPartitioner() - Constructor for class org.apache.cassandra.dht.RandomPartitioner
 
range - Variable in class org.apache.cassandra.db.IndexScanCommand
 
range - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
Range - Class in org.apache.cassandra.dht
A representation of the range that a node is responsible for on the DHT ring.
Range(Token, Token) - Constructor for class org.apache.cassandra.dht.Range
 
Range(Token, Token, IPartitioner) - Constructor for class org.apache.cassandra.dht.Range
 
range - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
RANGEOP - Static variable in class org.apache.cassandra.cql.CqlLexer
 
RANGEOP - Static variable in class org.apache.cassandra.cql.CqlParser
 
rangeSet(Range...) - Static method in class org.apache.cassandra.dht.Range
 
RangeSliceCommand - Class in org.apache.cassandra.db
 
RangeSliceCommand(String, ColumnParent, SlicePredicate, AbstractBounds, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceCommand(String, String, ByteBuffer, SlicePredicate, AbstractBounds, int) - Constructor for class org.apache.cassandra.db.RangeSliceCommand
 
RangeSliceReply - Class in org.apache.cassandra.db
 
RangeSliceReply(List<Row>) - Constructor for class org.apache.cassandra.db.RangeSliceReply
 
RangeSliceResponseResolver - Class in org.apache.cassandra.service
Turns RangeSliceReply objects into row (string -> CF) maps, resolving to the most recent ColumnFamily and setting up read repairs as necessary.
RangeSliceResponseResolver(String, List<InetAddress>) - Constructor for class org.apache.cassandra.service.RangeSliceResponseResolver
 
RangeSliceVerbHandler - Class in org.apache.cassandra.service
 
RangeSliceVerbHandler() - Constructor for class org.apache.cassandra.service.RangeSliceVerbHandler
 
read(Message) - Static method in class org.apache.cassandra.db.IndexScanCommand
 
read(Message) - Static method in class org.apache.cassandra.db.RangeSliceCommand
 
read(byte[], int) - Static method in class org.apache.cassandra.db.RangeSliceReply
 
read(DataInput) - Static method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
read() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
read(byte[]) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
read() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
read() - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
read(List<ReadCommand>, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
Performs the actual reading of a row out of the StorageService, fetching a specific set of column names from a given column family.
read() - Method in class org.apache.cassandra.streaming.IncomingStreamReader
 
read_repair_chance - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
readBoolean() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a boolean from the current position in this file.
readByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads an 8-bit byte from the current position in this file.
readBytes(int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
readBytes(int) - Method in interface org.apache.cassandra.io.util.FileDataInput
Read length bytes from current file position
readBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
Does the same thing as readFully do but without copying data (thread safe)
ReadCallback<T> - Class in org.apache.cassandra.service
 
ReadCallback(IResponseResolver<T>, ConsistencyLevel, IReadCommand, List<InetAddress>) - Constructor for class org.apache.cassandra.service.ReadCallback
Constructor when response count has to be calculated and blocked for.
readChar() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 16-bit character from the current position in this file.
readColumnFamily(List<ReadCommand>, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
ReadCommand - Class in org.apache.cassandra.db
 
ReadCommand(String, ByteBuffer, QueryPath, byte) - Constructor for class org.apache.cassandra.db.ReadCommand
 
readDouble() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 64-bit double from the current position in this file.
readFields(DataInput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
readFile() - Method in class org.apache.cassandra.streaming.IncomingStreamReader
 
readFloat() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 32-bit float from the current position in this file.
readFully(byte[]) - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads bytes from this file into buffer.
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
Read bytes from this file into buffer starting at offset offset.
readFully(byte[]) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
readFully(byte[], int, int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
readInt() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 32-bit integer from the current position in this file.
readLine() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a line of text form the current position in this file.
readLong() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 64-bit long from the current position in this file.
readnwrite(long, long, long, FileChannel) - Method in class org.apache.cassandra.security.streaming.SSLIncomingStreamReader
 
readnwrite(long, long, long, FileChannel) - Method in class org.apache.cassandra.streaming.IncomingStreamReader
 
readRepairChance(double) - Method in class org.apache.cassandra.config.CFMetaData
 
ReadRepairVerbHandler - Class in org.apache.cassandra.db
 
ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
 
ReadResponse - Class in org.apache.cassandra.db
 
ReadResponse(ByteBuffer) - Constructor for class org.apache.cassandra.db.ReadResponse
 
ReadResponse(Row) - Constructor for class org.apache.cassandra.db.ReadResponse
 
readRowSize(DataInput, Descriptor) - Static method in class org.apache.cassandra.io.sstable.SSTableReader
 
readSaved() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
readShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a 16-bit short from the current position in this file.
readUnsignedByte() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads an unsigned 8-bit byte from the current position in this file and returns it as an integer.
readUnsignedShort() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads an unsigned 16-bit short from the current position in this file and returns it as an integer.
readUTF() - Method in class org.apache.cassandra.io.util.AbstractDataInput
Reads a string that is encoded in modified UTF-8 from this file.
ReadVerbHandler - Class in org.apache.cassandra.db
 
ReadVerbHandler() - Constructor for class org.apache.cassandra.db.ReadVerbHandler
 
ReadVerbHandler.ReadContext - Class in org.apache.cassandra.db
 
ReadVerbHandler.ReadContext() - Constructor for class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
readWithLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
readWithShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
receive(Message, String) - Method in class org.apache.cassandra.net.MessagingService
 
received - Variable in class org.apache.cassandra.service.AsyncRepairCallback
 
received - Variable in class org.apache.cassandra.service.ReadCallback
 
received - Variable in class org.apache.cassandra.service.RepairCallback
 
receiveTiming(InetAddress, Double) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
receiveTiming(InetAddress, Double) - Method in interface org.apache.cassandra.locator.ILatencySubscriber
 
RECOMMENDED_DEPTH - Static variable in class org.apache.cassandra.utils.MerkleTree
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.Column
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.CounterColumn
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.DeletedColumn
 
reconcile(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
reconcile(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
recover() - Static method in class org.apache.cassandra.db.commitlog.CommitLog
 
recover(File[]) - Static method in class org.apache.cassandra.db.commitlog.CommitLog
 
rectify(UUID, InetAddress) - Static method in class org.apache.cassandra.service.MigrationManager
will either push or pull an updating depending on who is behind.
reduce(SSTableIdentityIterator) - Method in class org.apache.cassandra.io.CompactionIterator
 
reduce(T1) - Method in class org.apache.cassandra.utils.ReducingIterator
combine this object with the previous ones.
reduce_cache_capacity_to - Variable in class org.apache.cassandra.config.Config
 
reduce_cache_sizes_at - Variable in class org.apache.cassandra.config.Config
 
reduceCacheSize() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
reduceCacheSizes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
sets each cache's maximum capacity to 75% of its current size
reduceCacheSizes() - Method in class org.apache.cassandra.service.StorageService
 
ReducingIterator<T1,T2> - Class in org.apache.cassandra.utils
reduces equal values from the source iterator to a single (optionally transformed) instance.
ReducingIterator(Iterator<T1>) - Constructor for class org.apache.cassandra.utils.ReducingIterator
 
ReducingKeyIterator - Class in org.apache.cassandra.io.sstable
 
ReducingKeyIterator(Collection<SSTableReader>) - Constructor for class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
refreshEndpointMap() - Method in class org.apache.cassandra.client.RingCache
 
register(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Register for interesting state changes.
register(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.TokenMetadata
 
register(ILatencySubscriber) - Method in class org.apache.cassandra.net.MessagingService
 
registerDaemon(CassandraDaemon) - Method in class org.apache.cassandra.service.StorageService
 
registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
 
registerFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
Register interest for Failure Detector events.
registerMBean(Object) - Static method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
registerMBean() - Method in class org.apache.cassandra.db.HintedHandOffManager
 
registerVerbHandlers(StorageService.Verb, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
Register a verb and the corresponding verb handler with the Messaging Service.
relation() - Method in class org.apache.cassandra.cql.CqlParser
 
Relation - Class in org.apache.cassandra.cql
Relations encapsulate the relationship between an entity of some kind, and a value (term).
Relation(Term, String, Term) - Constructor for class org.apache.cassandra.cql.Relation
Creates a new relation.
release() - Method in interface org.apache.cassandra.scheduler.IRequestScheduler
A convenience method for indicating when a particular request has completed processing, and before a return to the client
release() - Method in class org.apache.cassandra.scheduler.NoScheduler
 
release() - Method in class org.apache.cassandra.scheduler.RoundRobinScheduler
 
releaseVersion() - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
reload() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
reloadConfiguration() - Method in class org.apache.cassandra.locator.PropertyFileSnitch
 
remainingBodyLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
remainingHeaderLength() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
remoteFile - Variable in class org.apache.cassandra.streaming.IncomingStreamReader
 
remove(K) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
remove(K) - Method in interface org.apache.cassandra.cache.ICache
 
remove(K) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
remove(K) - Method in class org.apache.cassandra.cache.SerializingCache
 
remove(Object) - Method in class org.apache.cassandra.concurrent.Context
 
remove(ByteBuffer) - Method in class org.apache.cassandra.db.ColumnFamily
 
remove() - Method in class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
remove() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
remove(ByteBuffer) - Method in interface org.apache.cassandra.db.IColumnContainer
 
remove() - Method in class org.apache.cassandra.db.RowIterator
 
remove(ByteBuffer) - Method in class org.apache.cassandra.db.SuperColumn
 
remove(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
remove(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
remove endpoint from failure detector
remove() - Method in class org.apache.cassandra.io.sstable.ReducingKeyIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
remove() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
remove(Object) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
remove(ByteBuffer, ColumnPath, long, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
remove() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
remove(K) - Method in class org.apache.cassandra.utils.ExpiringMap
 
remove(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Remove all elements set in other.
remove_counter(ByteBuffer, ColumnPath, ConsistencyLevel) - Method in class org.apache.cassandra.thrift.CassandraServer
 
removeAllSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeAllSSTables() - Method in class org.apache.cassandra.db.DataTracker
 
removeBootstrapToken(Token) - Method in class org.apache.cassandra.locator.TokenMetadata
 
REMOVED_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removeDeleted(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeDeletedCF(ColumnFamily, int) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
removeDeletedInCache(DecoratedKey) - Method in class org.apache.cassandra.io.CompactionController
 
removedNonlocal(Token, Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
removeEndpoint(InetAddress) - Method in class org.apache.cassandra.gms.Gossiper
Removes the endpoint completely from Gossip
removeEndpoint(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
removeFromMoving(InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
Remove pair of token/address from moving endpoints
removeHeader(String) - Method in class org.apache.cassandra.net.Message
 
removeOldShards(ByteBuffer, int) - Method in class org.apache.cassandra.db.context.CounterContext
Remove shards that have been canceled through computeOldShardMerger since a time older than gcBefore.
removeOldShards(ColumnFamily, int) - Static method in class org.apache.cassandra.db.CounterColumn
 
removeRegisteredCallback(String) - Method in class org.apache.cassandra.net.MessagingService
 
removeToken(Token) - Static method in class org.apache.cassandra.db.SystemTable
Remove stored token being used by another node
removeToken(String) - Method in class org.apache.cassandra.service.StorageService
Remove a node that has died, attempting to restore the replica count.
removeToken(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
removeToken removes token (and all data associated with enpoint that had it) from the ring
removeToken(String) - Method in class org.apache.cassandra.tools.NodeProbe
 
REMOVING_TOKEN - Static variable in class org.apache.cassandra.gms.VersionedValue
 
removingNonlocal(Token, Token) - Method in class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
rename(CFMetaData, String) - Static method in class org.apache.cassandra.config.CFMetaData
 
renameCf(Integer, String) - Method in class org.apache.cassandra.db.Table
basically a combined drop and add
RenameColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
RenameColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
RenameColumnFamily - Class in org.apache.cassandra.db.migration
Deprecated. 
RenameColumnFamily() - Constructor for class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated. Required no-arg constructor
RenameColumnFamily(String, String, String) - Constructor for class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
renameHints(String, String) - Static method in class org.apache.cassandra.db.HintedHandOffManager
called when a keyspace is dropped or rename.
RenameKeyspace - Class in org.apache.cassandra.db.migration.avro
 
RenameKeyspace() - Constructor for class org.apache.cassandra.db.migration.avro.RenameKeyspace
 
RenameKeyspace - Class in org.apache.cassandra.db.migration
Deprecated. 
RenameKeyspace() - Constructor for class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated. Required no-arg constructor
RenameKeyspace(String, String) - Constructor for class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
renameSSTables(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
renameTable(CFMetaData, String) - Static method in class org.apache.cassandra.config.CFMetaData
 
renameWithConfirm(File, File) - Static method in class org.apache.cassandra.io.util.FileUtils
 
renameWithConfirm(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
renewLocalId() - Static method in class org.apache.cassandra.utils.NodeId
Renew the local node id.
renewMemtable() - Method in class org.apache.cassandra.db.DataTracker
Renew the current memtable without putting the old one for a flush.
RepairCallback<T> - Class in org.apache.cassandra.service
 
RepairCallback(IResponseResolver<T>, List<InetAddress>) - Constructor for class org.apache.cassandra.service.RepairCallback
The main difference between this and ReadCallback is, ReadCallback has a ConsistencyLevel it needs to achieve.
replaceCompactedSSTables(Collection<SSTableReader>, Iterable<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
 
replaceFlushed(Memtable, SSTableReader) - Method in class org.apache.cassandra.db.DataTracker
 
ReplayPosition - Class in org.apache.cassandra.db.commitlog
 
ReplayPosition(long, int) - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition
 
replayPosition - Variable in class org.apache.cassandra.io.sstable.SSTable
 
ReplayPosition.ReplayPositionSerializer - Class in org.apache.cassandra.db.commitlog
 
ReplayPosition.ReplayPositionSerializer() - Constructor for class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
replica_placement_strategy() - Method in class org.apache.cassandra.cli.CliParser
 
replicate_on_write - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
replicateOnWrite(boolean) - Method in class org.apache.cassandra.config.CFMetaData
 
replication_factor - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
ReplicationFinishedVerbHandler - Class in org.apache.cassandra.streaming
 
ReplicationFinishedVerbHandler() - Constructor for class org.apache.cassandra.streaming.ReplicationFinishedVerbHandler
 
ReplicationStrategy - Class in org.apache.cassandra.config
 
ReplicationStrategy() - Constructor for class org.apache.cassandra.config.ReplicationStrategy
 
replies - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
report(InetAddress) - Method in class org.apache.cassandra.gms.FailureDetector
 
report(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by the receiver of the heartbeat.
reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliLexer
 
reportError(RecognitionException) - Method in class org.apache.cassandra.cli.CliParser
 
representJavaBeanProperty(Object, Property, Object, Tag) - Method in class org.apache.cassandra.utils.SkipNullRepresenter
 
request - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
request - Variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
request_scheduler - Variable in class org.apache.cassandra.config.Config
 
request_scheduler_id - Variable in class org.apache.cassandra.config.Config
 
request_scheduler_options - Variable in class org.apache.cassandra.config.Config
 
REQUEST_TIMEOUT - Static variable in class org.apache.cassandra.service.AntiEntropyService
 
requestGC() - Method in class org.apache.cassandra.service.StorageService
 
requestRanges(InetAddress, String, Collection<Range>, Runnable, OperationType) - Static method in class org.apache.cassandra.streaming.StreamIn
Request ranges to be transferred from source to local node
RequestSchedulerOptions - Class in org.apache.cassandra.config
 
RequestSchedulerOptions() - Constructor for class org.apache.cassandra.config.RequestSchedulerOptions
 
requiresKeyspace - Static variable in enum org.apache.cassandra.cql.StatementType
 
reset() - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
reset() - Method in class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
reset() - Method in class org.apache.cassandra.io.sstable.SSTableWriter
 
reset() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
reset(FileMark) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
reset() - Method in class org.apache.cassandra.io.util.DataOutputBuffer
Resets the buffer to empty.
reset(FileMark) - Method in interface org.apache.cassandra.io.util.FileDataInput
 
reset(FileMark) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
reset() - Method in class org.apache.cassandra.service.ClientState
 
reset() - Method in class org.apache.cassandra.utils.SimpleCondition
 
resetUnsafe() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
resolve(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
resolve() - Method in interface org.apache.cassandra.service.IResponseResolver
This Method resolves the responses that are passed in .
resolve() - Method in class org.apache.cassandra.service.RangeSliceResponseResolver
 
resolve() - Method in class org.apache.cassandra.service.RowDigestResolver
 
resolve() - Method in class org.apache.cassandra.service.RowRepairResolver
 
resolver - Variable in class org.apache.cassandra.service.ReadCallback
 
Resources - Class in org.apache.cassandra.auth
Constants related to Cassandra's resource hierarchy.
Resources() - Constructor for class org.apache.cassandra.auth.Resources
 
resourceToFile(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
ResourceWatcher - Class in org.apache.cassandra.utils
 
ResourceWatcher() - Constructor for class org.apache.cassandra.utils.ResourceWatcher
 
ResourceWatcher.WatchedResource - Class in org.apache.cassandra.utils
 
ResourceWatcher.WatchedResource(String, Runnable) - Constructor for class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
response(Message) - Method in interface org.apache.cassandra.net.IAsyncCallback
 
response(Message) - Method in class org.apache.cassandra.service.AbstractWriteResponseHandler
null message means "response from local write"
response(Message) - Method in class org.apache.cassandra.service.AsyncRepairCallback
 
response(Message) - Method in class org.apache.cassandra.service.DatacenterSyncWriteResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.DatacenterWriteResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.ReadCallback
 
response(ReadResponse) - Method in class org.apache.cassandra.service.ReadCallback
 
response(Message) - Method in class org.apache.cassandra.service.RepairCallback
 
response(Message) - Method in class org.apache.cassandra.service.TruncateResponseHandler
 
response(Message) - Method in class org.apache.cassandra.service.WriteResponseHandler
 
responses - Variable in class org.apache.cassandra.service.RangeSliceResponseResolver
 
responses - Variable in class org.apache.cassandra.service.TruncateResponseHandler
 
responses - Variable in class org.apache.cassandra.service.WriteResponseHandler
 
ResponseVerbHandler - Class in org.apache.cassandra.net
 
ResponseVerbHandler() - Constructor for class org.apache.cassandra.net.ResponseVerbHandler
 
result(Message) - Method in interface org.apache.cassandra.net.IAsyncResult
Store the result obtained for the submitted task.
retry(PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
retry() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
RETRY_DELAY - Static variable in class org.apache.cassandra.io.sstable.SSTableDeletingReference
 
RetryingScheduledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
 
RetryingScheduledThreadPoolExecutor(String, int) - Constructor for class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
RetryingScheduledThreadPoolExecutor(int, String, int) - Constructor for class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
RetryingScheduledThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.RetryingScheduledThreadPoolExecutor
 
reverseComparator - Variable in class org.apache.cassandra.db.marshal.AbstractType
 
reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
reversed - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
revive(InetAddress) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
right - Variable in class org.apache.cassandra.dht.AbstractBounds
 
right - Variable in class org.apache.cassandra.utils.Pair
 
RING_DELAY - Static variable in class org.apache.cassandra.service.StorageService
 
RingCache - Class in org.apache.cassandra.client
A class for caching the ring map at the client.
RingCache(String, IPartitioner<?>, String, int) - Constructor for class org.apache.cassandra.client.RingCache
 
ringIterator(ArrayList<Token>, Token, boolean) - Static method in class org.apache.cassandra.locator.TokenMetadata
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)
rm - Variable in class org.apache.cassandra.db.migration.Migration
 
ROOT - Static variable in class org.apache.cassandra.auth.Resources
 
root() - Method in class org.apache.cassandra.cli.CliParser
 
RoundRobinScheduler - Class in org.apache.cassandra.scheduler
A very basic Round Robin implementation of the RequestScheduler.
RoundRobinScheduler(RequestSchedulerOptions) - Constructor for class org.apache.cassandra.scheduler.RoundRobinScheduler
 
row() - Method in class org.apache.cassandra.db.ReadResponse
 
Row - Class in org.apache.cassandra.db
 
Row(DecoratedKey<?>, ColumnFamily) - Constructor for class org.apache.cassandra.db.Row
 
row_cache_provider - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
row_cache_save_period_in_seconds - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
row_cache_size - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
row_mutation - Variable in class org.apache.cassandra.db.migration.avro.Migration
 
rowCache - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
rowCacheProvider(IRowCacheProvider) - Method in class org.apache.cassandra.config.CFMetaData
 
rowCacheSavePeriod(int) - Method in class org.apache.cassandra.config.CFMetaData
 
rowCacheSize(double) - Method in class org.apache.cassandra.config.CFMetaData
 
RowDigestResolver - Class in org.apache.cassandra.service
 
RowDigestResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowDigestResolver
 
RowIterator - Class in org.apache.cassandra.db
Row iterator that allows us to close the underlying iterators.
RowIterator(ReducingIterator<IColumnIterator, Row>, List<Iterator<IColumnIterator>>) - Constructor for class org.apache.cassandra.db.RowIterator
 
RowIteratorFactory - Class in org.apache.cassandra.db
 
RowIteratorFactory() - Constructor for class org.apache.cassandra.db.RowIteratorFactory
 
rowKey() - Method in class org.apache.cassandra.cli.CliParser
 
rowMutation() - Method in class org.apache.cassandra.db.CounterMutation
 
RowMutation - Class in org.apache.cassandra.db
 
RowMutation(String, ByteBuffer) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, Row) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, ByteBuffer, Map<Integer, ColumnFamily>) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation.RowMutationSerializer - Class in org.apache.cassandra.db
 
RowMutation.RowMutationSerializer() - Constructor for class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
RowMutationVerbHandler - Class in org.apache.cassandra.db
 
RowMutationVerbHandler() - Constructor for class org.apache.cassandra.db.RowMutationVerbHandler
 
RowRepairResolver - Class in org.apache.cassandra.service
 
RowRepairResolver(String, ByteBuffer) - Constructor for class org.apache.cassandra.service.RowRepairResolver
 
rows - Variable in class org.apache.cassandra.db.RangeSliceReply
 
rows - Variable in class org.apache.cassandra.io.CompactionIterator
 
rpc_address - Variable in class org.apache.cassandra.config.Config
 
rpc_keepalive - Variable in class org.apache.cassandra.config.Config
 
rpc_max_threads - Variable in class org.apache.cassandra.config.Config
 
rpc_min_threads - Variable in class org.apache.cassandra.config.Config
 
rpc_port - Variable in class org.apache.cassandra.config.Config
 
rpc_recv_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
rpc_send_buff_size_in_bytes - Variable in class org.apache.cassandra.config.Config
 
rpc_timeout_in_ms - Variable in class org.apache.cassandra.config.Config
 
rtree - Variable in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
run() - Method in class org.apache.cassandra.net.IncomingTcpConnection
A new connection will either stream or message for its entire lifetime: because streaming bypasses the InputStream implementations to use sendFile, we cannot begin buffering until we've determined the type of the connection.
run() - Method in class org.apache.cassandra.net.MessageDeliveryTask
 
run() - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
run() - Method in class org.apache.cassandra.service.AntiEntropyService.Differencer
Compares our trees, and triggers repairs for any ranges that mismatch.
run() - Method in class org.apache.cassandra.service.AntiEntropyService.Validator
Called after the validation lifecycle to respond with the now valid tree.
run() - Method in class org.apache.cassandra.utils.ResourceWatcher.WatchedResource
 
run() - Method in class org.apache.cassandra.utils.WrappedRunnable
 
runMayThrow() - Method in class org.apache.cassandra.streaming.FileStreamTask
 
runMayThrow() - Method in class org.apache.cassandra.utils.WrappedRunnable
 

S

S - Static variable in class org.apache.cassandra.cql.CqlLexer
 
S - Static variable in class org.apache.cassandra.cql.CqlParser
 
saveCache() - Method in class org.apache.cassandra.cache.AutoSavingCache.Writer
 
saveCaches() - Method in class org.apache.cassandra.service.StorageService
 
saveCaches() - Method in interface org.apache.cassandra.service.StorageServiceMBean
save row and key caches
saved_caches_directory - Variable in class org.apache.cassandra.config.Config
 
saveTask - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
scan(IndexClause, AbstractBounds, IFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scan(String, String, IndexClause, SlicePredicate, ConsistencyLevel) - Static method in class org.apache.cassandra.service.StorageProxy
 
scheduleCacheSaving(int, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scheduledTasks - Static variable in class org.apache.cassandra.service.StorageService
This pool is used for periodic short (sub-second) tasks.
scheduleSaving(int) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.AddColumnFamily
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.AddKeyspace
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.CfDef
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.DropColumnFamily
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.DropKeyspace
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.KsDef
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.Migration
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.RenameColumnFamily
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.RenameKeyspace
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
SCHEMA$ - Static variable in class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
SCHEMA_CF - Static variable in class org.apache.cassandra.db.migration.Migration
 
schema_mwt - Variable in class org.apache.cassandra.cli.CliSessionState
 
SchemaCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
SchemaCheckVerbHandler - Class in org.apache.cassandra.db
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
SchemaCheckVerbHandler() - Constructor for class org.apache.cassandra.db.SchemaCheckVerbHandler
 
scrub() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
scrub(String, String...) - Method in class org.apache.cassandra.service.StorageService
 
scrub(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Scrub (deserialize + reserialize at the latest version, skipping bad rows if any) the given keyspace.
scrub(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
 
scrubDataDirectories(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
Removes unnecessary files from the cf directory at startup: these include temp files, orphans, zero-length files and compacted sstables.
sections - Variable in class org.apache.cassandra.streaming.PendingFile
 
seed_provider - Variable in class org.apache.cassandra.config.Config
 
SeedProvider - Interface in org.apache.cassandra.locator
 
SeedProviderDef - Class in org.apache.cassandra.config
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
SeedProviderDef(LinkedHashMap) - Constructor for class org.apache.cassandra.config.SeedProviderDef
 
seek(long) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.AbstractDataInput
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
seekInternal(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
seekTo(DecoratedKey) - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
segment - Variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
SegmentedFile - Class in org.apache.cassandra.io.util
Abstracts a read-only file that has been split into segments, each of which can be represented by an independent FileDataInput.
SegmentedFile.Builder - Class in org.apache.cassandra.io.util
Collects potential segmentation points in an underlying file, and builds a SegmentedFile to represent it.
SegmentedFile.Builder() - Constructor for class org.apache.cassandra.io.util.SegmentedFile.Builder
 
selectExpression() - Method in class org.apache.cassandra.cql.CqlParser
 
SelectExpression - Class in org.apache.cassandra.cql
Select expressions are analogous to the projection in a SQL query.
SelectExpression(Term, Term, int, boolean, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
Create a new SelectExpression for a range (slice) of columns.
SelectExpression(Term, int, boolean) - Constructor for class org.apache.cassandra.cql.SelectExpression
Create a new SelectExpression for a list of columns.
selectStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
SelectStatement - Class in org.apache.cassandra.cql
Encapsulates a completely parsed SELECT query, including the target column family, expression, result count, and ordering clause.
SelectStatement(SelectExpression, boolean, String, ConsistencyLevel, WhereClause, int) - Constructor for class org.apache.cassandra.cql.SelectStatement
 
SEMICOLON - Static variable in class org.apache.cassandra.cli.CliLexer
 
SEMICOLON - Static variable in class org.apache.cassandra.cli.CliParser
 
sendOneWay(Message, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendReply(Message, String, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message, InetAddress, IMessageCallback) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendRR(MessageProducer, InetAddress, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
Send a message to a given endpoint.
sendRR(Message, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
 
SerDeUtils - Class in org.apache.cassandra.io
Static serialization/deserialization utility functions, intended to eventually replace ICompactSerializers.
SerDeUtils() - Constructor for class org.apache.cassandra.io.SerDeUtils
 
serializationFlags() - Method in class org.apache.cassandra.db.Column
 
serializationFlags() - Method in class org.apache.cassandra.db.CounterColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.CounterUpdateColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.DeletedColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.ExpiringColumn
 
serializationFlags() - Method in interface org.apache.cassandra.db.IColumn
 
serializationFlags() - Method in class org.apache.cassandra.db.SuperColumn
 
serialize(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serialize(IIterableColumns, DataOutput) - Static method in class org.apache.cassandra.db.ColumnIndexer
Given a column family this, function creates an in-memory structure that represents the column index for the column family, and subsequently writes it to disk.
serialize(IColumn, DataOutput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
serialize(ReplayPosition, DataOutput) - Method in class org.apache.cassandra.db.commitlog.ReplayPosition.ReplayPositionSerializer
 
serialize(DataOutputStream) - Method in class org.apache.cassandra.db.filter.QueryPath
 
serialize() - Method in class org.apache.cassandra.db.migration.Migration
 
serialize(RowMutation, DataOutputStream, int) - Method in class org.apache.cassandra.db.RowMutation.RowMutationSerializer
 
serialize(TruncateResponse, DataOutputStream, int) - Method in class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
serialize(WriteResponse, DataOutputStream, int) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
serialize(Token, DataOutput) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serialize(T, DataOutputStream, int) - Method in interface org.apache.cassandra.io.ICompactSerializer
Serialize the specified type into the specified DataOutputStream instance.
serialize(T, DataOutput) - Method in interface org.apache.cassandra.io.ICompactSerializer2
Serialize the specified type into the specified DataOutput instance.
serialize(T) - Static method in class org.apache.cassandra.io.SerDeUtils
Serializes a single object.
serialize(DataOutput) - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
serialize(InetAddress, DataOutputStream) - Static method in class org.apache.cassandra.net.CompactEndpointSerializationHelper
 
serialize(AntiEntropyService.TreeRequest, DataOutputStream, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
serialize(AntiEntropyService.Validator, DataOutputStream, int) - Method in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
serialize(PendingFile, DataOutputStream, int) - Method in class org.apache.cassandra.streaming.PendingFile.PendingFileSerializer
 
serialize(EstimatedHistogram, DataOutput) - Method in class org.apache.cassandra.utils.EstimatedHistogram.EstimatedHistogramSerializer
 
serialize(TSerializer, TBase, DataOutput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
serialize(MerkleTree, DataOutputStream, int) - Method in class org.apache.cassandra.utils.MerkleTree.MerkleTreeSerializer
 
serializeCFInfo(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize() - Method in class org.apache.cassandra.db.Column
 
serializedSize() - Method in class org.apache.cassandra.db.ColumnFamily
 
serializedSize(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializedSize() - Method in interface org.apache.cassandra.db.IColumn
 
serializedSize() - Method in class org.apache.cassandra.db.SuperColumn
This returns the size of the super-column when serialized.
serializedSize(T) - Method in interface org.apache.cassandra.io.ICompactSerializer3
 
serializedSize() - Method in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
serializeForSSTable(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeInternal(IIterableColumns, DataOutput) - Static method in class org.apache.cassandra.db.ColumnIndexer
 
serializer() - Static method in class org.apache.cassandra.db.Column
 
serializer() - Static method in class org.apache.cassandra.db.ColumnFamily
 
serializer - Static variable in class org.apache.cassandra.db.commitlog.ReplayPosition
 
serializer() - Static method in class org.apache.cassandra.db.CounterMutation
 
serializer() - Static method in class org.apache.cassandra.db.ReadCommand
 
serializer() - Static method in class org.apache.cassandra.db.ReadResponse
 
serializer() - Static method in class org.apache.cassandra.db.Row
 
serializer() - Static method in class org.apache.cassandra.db.RowMutation
 
serializer(AbstractType) - Static method in class org.apache.cassandra.db.SuperColumn
 
serializer() - Static method in class org.apache.cassandra.db.TruncateResponse
 
serializer() - Static method in class org.apache.cassandra.db.Truncation
 
serializer() - Static method in class org.apache.cassandra.db.WriteResponse
 
serializer() - Static method in class org.apache.cassandra.dht.AbstractBounds
 
serializer() - Static method in class org.apache.cassandra.dht.Token
 
serializer() - Static method in class org.apache.cassandra.gms.EndpointState
 
serializer() - Static method in class org.apache.cassandra.gms.GossipDigest
 
serializer - Static variable in class org.apache.cassandra.gms.VersionedValue
 
serializer() - Static method in class org.apache.cassandra.net.Message
 
SERIALIZER - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
SERIALIZER - Static variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequestVerbHandler
 
SERIALIZER - Static variable in class org.apache.cassandra.service.AntiEntropyService.TreeResponseVerbHandler
 
serializer() - Static method in class org.apache.cassandra.streaming.PendingFile
 
serializer() - Static method in class org.apache.cassandra.streaming.StreamHeader
 
serializer() - Static method in class org.apache.cassandra.utils.BloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.EstimatedHistogram
 
serializer() - Static method in class org.apache.cassandra.utils.LegacyBloomFilter
 
serializer - Static variable in class org.apache.cassandra.utils.MerkleTree
 
SerializerType - Enum in org.apache.cassandra.net.io
 
serializerType_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
serializeWithIndexes(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializeWithSchema(T) - Static method in class org.apache.cassandra.io.SerDeUtils
Serializes a single object along with its Schema.
SerializingCache<K,V> - Class in org.apache.cassandra.cache
Serializes cache values off-heap.
SerializingCache(int, ICompactSerializer3<V>) - Constructor for class org.apache.cassandra.cache.SerializingCache
 
SerializingCacheProvider - Class in org.apache.cassandra.cache
 
SerializingCacheProvider() - Constructor for class org.apache.cassandra.cache.SerializingCacheProvider
 
serialVersionUID - Static variable in class org.apache.cassandra.dht.Range
 
serialVersionUID - Static variable in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
serve() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
 
session - Variable in class org.apache.cassandra.streaming.IncomingStreamReader
 
sessionid - Variable in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
sessionId - Variable in class org.apache.cassandra.streaming.StreamHeader
session is tuple of (host, sessionid)
sessionState - Static variable in class org.apache.cassandra.cli.CliMain
 
SET - Static variable in class org.apache.cassandra.cli.CliLexer
 
SET - Static variable in class org.apache.cassandra.cli.CliParser
 
set(double) - Method in class org.apache.cassandra.utils.DefaultDouble
 
set(int) - Method in class org.apache.cassandra.utils.DefaultInteger
 
set(long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
sets a bit, expanding the set size if necessary
set(long, long) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Sets a range of bits, expanding the set size if necessary
set_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
setArray(int, Array) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setAsciiStream(int, InputStream) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setAsciiStream(int, InputStream, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setAsciiStream(int, InputStream, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBigDecimal(int, BigDecimal) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBinaryStream(int, InputStream) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBinaryStream(int, InputStream, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBinaryStream(int, InputStream, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBits(long[]) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: sets a new long[] to use as the bit storage
setBlob(int, Blob) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBlob(int, InputStream) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBlob(int, InputStream, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBoolean(int, boolean) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBootstrapped(boolean) - Static method in class org.apache.cassandra.db.SystemTable
 
setByte(int, byte) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setBytes(int, byte[]) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setCacheCapacities(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
 
setCapacity(int) - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
setCapacity(int) - Method in interface org.apache.cassandra.cache.ICache
 
setCapacity(int) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
setCapacity(int) - Method in interface org.apache.cassandra.cache.InstrumentingCacheMBean
 
setCapacity(int) - Method in class org.apache.cassandra.cache.SerializingCache
 
setCharacterStream(int, Reader) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setCharacterStream(int, Reader, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setCharacterStream(int, Reader, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setClob(int, Clob) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setClob(int, Reader) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setClob(int, Reader, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setColumnsLimit(int) - Method in class org.apache.cassandra.cql.SelectExpression
 
setColumnsReversed(boolean) - Method in class org.apache.cassandra.cql.SelectExpression
 
setCompactionThreshold(String, String, int, int) - Method in class org.apache.cassandra.tools.NodeProbe
Set the compaction threshold
setCompactionThroughput(int) - Method in class org.apache.cassandra.tools.NodeProbe
 
setCompactionThroughputMbPerSec(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setCompactionThroughputMbPerSec(int) - Method in class org.apache.cassandra.service.StorageService
 
setCompactionThroughputMbPerSec(int) - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
setCorePoolSize(int) - Method in interface org.apache.cassandra.concurrent.JMXConfigurableThreadPoolExecutorMBean
 
setCurrentFile(PendingFile) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setDate(int, Date) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setDate(int, Date, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
 
setDouble(int, double) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setDynamicBadnessThreshold(Double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDynamicResetInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setDynamicUpdateInterval(Integer) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setEndpointSnitch(IEndpointSnitch) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setErr(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
 
setFloat(int, float) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setHasToken(boolean) - Method in class org.apache.cassandra.gms.EndpointState
 
setHeader(String, byte[]) - Method in class org.apache.cassandra.net.Message
 
setHintedHandoffEnabled(boolean) - Method in class org.apache.cassandra.service.StorageProxy
 
setHintedHandoffEnabled(boolean) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setIndexBuilt(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
setIndexName(String) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setIndexRemoved(String, String) - Static method in class org.apache.cassandra.db.SystemTable
 
setIndexType(IndexType) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setInitialAddress(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setInputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace and column family for the input of this job.
setInputSlicePredicate(Configuration, SlicePredicate) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the predicate that determines what columns will be selected from each row.
setInputSplitSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the size of the input split.
setInt(int, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setKeyCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setKeyCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setKeyCountToImport(Integer) - Static method in class org.apache.cassandra.tools.SSTableImport
Used by test framework to set key count
setKeySpace(String) - Method in class org.apache.cassandra.cli.CliClient
 
setKeyspace(String) - Method in class org.apache.cassandra.service.ClientState
 
setKeyType(String) - Method in class org.apache.cassandra.cql.CreateColumnFamilyStatement
 
setLength(long) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
setLog4jLevel(String, String) - Method in class org.apache.cassandra.service.StorageService
 
setLog4jLevel(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
set the logging level at runtime
setLong(int, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setMaxHintWindow(int) - Method in class org.apache.cassandra.service.StorageProxy
 
setMaxHintWindow(int) - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
setMaximumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMaximumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the maximum number of sstables in queue before compaction kicks off
setMemtableFlushAfterMins(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMemtableFlushAfterMins(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setMemtableOperationsInMillions(double) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMemtableOperationsInMillions(double) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setMemtableThroughputInMB(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMemtableThroughputInMB(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setMinimumCompactionThreshold(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setMinimumCompactionThreshold(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
Sets the minimum number of sstables in queue before compaction kicks off
setNCharacterStream(int, Reader) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNCharacterStream(int, Reader, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNClob(int, NClob) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNClob(int, Reader) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNClob(int, Reader, long) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNString(int, String) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNull(int, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNull(int, int, String) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setNumWords(int) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Expert: sets the number of longs in the array that are in use
setObject(int, Object) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setObject(int, Object, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setObject(int, Object, int, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setOut(PrintStream) - Method in class org.apache.cassandra.cli.CliSessionState
 
setOutputColumnFamily(Configuration, String, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
Set the keyspace and column family for the output of this job.
setPartitioner(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setPendingRanges(String, Multimap<Range, InetAddress>) - Method in class org.apache.cassandra.locator.TokenMetadata
 
setPhiConvictThreshold(int) - Method in class org.apache.cassandra.gms.FailureDetector
 
setPhiConvictThreshold(int) - Method in interface org.apache.cassandra.gms.FailureDetectorMBean
 
setRangeBatchSize(Configuration, int) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
The number of rows to request with each get range slices request.
setRef(int, Ref) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setRowCacheSavePeriodInSeconds(int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
setRowCacheSavePeriodInSeconds(int) - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
setRowId(int, RowId) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setRpcPort(Configuration, String) - Static method in class org.apache.cassandra.hadoop.ConfigHelper
 
setShort(int, short) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setSQLXML(int, SQLXML) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setStatement() - Method in class org.apache.cassandra.cli.CliParser
 
setString(int, String) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setTable(String) - Method in class org.apache.cassandra.streaming.StreamInSession
 
setTableDefinition(KSMetaData, UUID) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTime(int, Time) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setTime(int, Time, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setTimestamp(int, Timestamp) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setTimestamp(int, Timestamp, Calendar) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setToken(Token) - Method in class org.apache.cassandra.service.StorageService
This method updates the local token on disk
setTrackedBy(DataTracker) - Method in class org.apache.cassandra.io.sstable.SSTableReader
 
setTreeAdaptor(TreeAdaptor) - Method in class org.apache.cassandra.cli.CliParser
 
setUnicodeStream(int, InputStream, int) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setup() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
This is a hook for concrete daemons to initialize themselves suitably.
setupJob(JobContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
setupTask(TaskAttemptContext) - Method in class org.apache.cassandra.hadoop.ColumnFamilyOutputFormat.NullOutputCommitter
 
setURL(int, URL) - Method in class org.apache.cassandra.cql.jdbc.CassandraPreparedStatement
 
setUsername(String) - Method in class org.apache.cassandra.cli.CliClient
 
setValidator(AbstractType) - Method in class org.apache.cassandra.config.ColumnDefinition
 
setVersion(InetAddress, int) - Method in class org.apache.cassandra.gms.Gossiper
 
shallowCopy() - Method in class org.apache.cassandra.db.SuperColumn
 
shortSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
shouldAddEntry() - Method in class org.apache.cassandra.io.sstable.IndexSummary
 
shouldHint(InetAddress) - Static method in class org.apache.cassandra.service.StorageProxy
 
shouldPurge(DecoratedKey) - Method in class org.apache.cassandra.io.CompactionController
 
shouldReplicateOnWrite() - Method in class org.apache.cassandra.db.CounterMutation
 
SHOW - Static variable in class org.apache.cassandra.cli.CliLexer
 
SHOW - Static variable in class org.apache.cassandra.cli.CliParser
 
showClusterName() - Method in class org.apache.cassandra.cli.CliParser
 
showKeyspaces() - Method in class org.apache.cassandra.cli.CliParser
 
showStatement() - Method in class org.apache.cassandra.cli.CliParser
 
showVersion() - Method in class org.apache.cassandra.cli.CliParser
 
shutdown() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdown() - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
shuts down the CommitLogExecutor in an orderly fashion
shutdown() - Method in class org.apache.cassandra.net.MessagingService
 
shutdown() - Method in class org.apache.cassandra.utils.ExpiringMap
 
shutdownBlocking() - Method in class org.apache.cassandra.db.commitlog.CommitLog
 
shutdownNow() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Attempts to stop all actively executing tasks, halts the processing of waiting tasks, and returns a list of the tasks that were awaiting execution.
shutdownNow() - Method in class org.apache.cassandra.concurrent.JMXEnabledThreadPoolExecutor
 
shutdownNow() - Static method in class org.apache.cassandra.concurrent.StageManager
This method shuts down all registered stages.
shutdownNow() - Method in class org.apache.cassandra.db.commitlog.AbstractCommitLogExecutorService
 
signal() - Method in class org.apache.cassandra.utils.SimpleCondition
 
signalAll() - Method in class org.apache.cassandra.utils.SimpleCondition
 
SimpleAbstractColumnIterator - Class in org.apache.cassandra.db.columniterator
 
SimpleAbstractColumnIterator() - Constructor for class org.apache.cassandra.db.columniterator.SimpleAbstractColumnIterator
 
SimpleAuthenticator - Class in org.apache.cassandra.auth
 
SimpleAuthenticator() - Constructor for class org.apache.cassandra.auth.SimpleAuthenticator
 
SimpleAuthenticator.PasswordMode - Enum in org.apache.cassandra.auth
 
SimpleAuthority - Class in org.apache.cassandra.auth
 
SimpleAuthority() - Constructor for class org.apache.cassandra.auth.SimpleAuthority
 
SimpleCondition - Class in org.apache.cassandra.utils
 
SimpleCondition() - Constructor for class org.apache.cassandra.utils.SimpleCondition
 
SimpleSeedProvider - Class in org.apache.cassandra.locator
 
SimpleSeedProvider(Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleSeedProvider
 
SimpleSnitch - Class in org.apache.cassandra.locator
A simple endpoint snitch implementation that treats Strategy order as proximity, allowing non-read-repaired reads to prefer a single endpoint, which improves cache locality.
SimpleSnitch() - Constructor for class org.apache.cassandra.locator.SimpleSnitch
 
SimpleStrategy - Class in org.apache.cassandra.locator
This class returns the nodes responsible for a given key but does not respect rack awareness.
SimpleStrategy(String, TokenMetadata, IEndpointSnitch, Map<String, String>) - Constructor for class org.apache.cassandra.locator.SimpleStrategy
 
SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
SingleEscapeCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliLexer
 
SingleStringCharacter - Static variable in class org.apache.cassandra.cli.CliParser
 
singleton(T) - Static method in class org.apache.cassandra.utils.FBUtilities
 
SinkManager - Class in org.apache.cassandra.net.sink
 
SinkManager() - Constructor for class org.apache.cassandra.net.sink.SinkManager
 
size() - Method in class org.apache.cassandra.cache.ConcurrentLinkedHashCache
 
size() - Method in interface org.apache.cassandra.cache.ICache
 
size() - Method in class org.apache.cassandra.cache.InstrumentingCache
 
size() - Method in interface org.apache.cassandra.cache.InstrumentingCacheMBean
 
size() - Method in class org.apache.cassandra.cache.SerializingCache
 
size() - Method in class org.apache.cassandra.db.Column
 
size() - Method in class org.apache.cassandra.db.CounterColumn
 
size() - Method in class org.apache.cassandra.db.ExpiringColumn
 
size() - Method in interface org.apache.cassandra.db.IColumn
 
size() - Method in class org.apache.cassandra.db.SuperColumn
This calculates the exact size of the sub columns on the fly
size() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
size - Variable in class org.apache.cassandra.streaming.PendingFile
 
size() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
size() - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
size() - Method in class org.apache.cassandra.utils.ExpiringMap
 
size() - Method in class org.apache.cassandra.utils.MerkleTree
The number of distinct ranges contained in this tree.
size() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the current capacity of this set.
sizeMemtableOperations(int) - Static method in class org.apache.cassandra.config.CFMetaData
 
sizeMemtableThroughput() - Static method in class org.apache.cassandra.config.CFMetaData
 
skipBloomFilter(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Skip the bloom filter
skipBytes(int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
skipBytes(int) - Method in class org.apache.cassandra.io.util.MemoryInputStream
 
skipBytesFully(DataInput, int) - Static method in class org.apache.cassandra.io.util.FileUtils
 
skipBytesFully(DataInput, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
skipIndex(FileDataInput) - Static method in class org.apache.cassandra.io.sstable.IndexHelper
Skip the index
SkipNullRepresenter - Class in org.apache.cassandra.utils
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
SkipNullRepresenter() - Constructor for class org.apache.cassandra.utils.SkipNullRepresenter
 
skipShortLength(DataInput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
SliceByNamesReadCommand - Class in org.apache.cassandra.db
 
SliceByNamesReadCommand(String, ByteBuffer, ColumnParent, Collection<ByteBuffer>) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
 
SliceByNamesReadCommand(String, ByteBuffer, QueryPath, Collection<ByteBuffer>) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
 
sliced_buffer_size_in_kb - Variable in class org.apache.cassandra.config.Config
 
SliceFromReadCommand - Class in org.apache.cassandra.db
 
SliceFromReadCommand(String, ByteBuffer, ColumnParent, ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceFromReadCommand(String, ByteBuffer, QueryPath, ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceQueryFilter - Class in org.apache.cassandra.db.filter
 
SliceQueryFilter(ByteBuffer, ByteBuffer, boolean, int) - Constructor for class org.apache.cassandra.db.filter.SliceQueryFilter
 
snapshot(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
Take a snap shot of this columnfamily store.
snapshot(String) - Method in class org.apache.cassandra.db.Table
Take a snapshot of the entire set of column families with a given timestamp
snapshot_before_compaction - Variable in class org.apache.cassandra.config.Config
 
snapshotExists(String) - Method in class org.apache.cassandra.db.Table
? Clear snapshots for this table.
snitch - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractEndpointSnitch
 
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.AbstractNetworkTopologySnitch
Sorts the List of node addresses by proximity to the given address
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
sortByProximity(InetAddress, List<InetAddress>) - Method in interface org.apache.cassandra.locator.IEndpointSnitch
This method will sort the List by proximity to the given address.
sortByProximity(InetAddress, List<InetAddress>) - Method in class org.apache.cassandra.locator.SimpleSnitch
 
sortedTokens() - Method in class org.apache.cassandra.locator.TokenMetadata
 
sortSampledKeys(List<DecoratedKey>, Range) - Static method in class org.apache.cassandra.utils.FBUtilities
 
source - Variable in class org.apache.cassandra.utils.ReducingIterator
 
spaceReclaimed(long) - Method in class org.apache.cassandra.db.DataTracker
 
split(Token) - Method in class org.apache.cassandra.dht.AbstractBounds
Given token T and AbstractBounds ?L,R], returns Pair(?L,T], ?T,R]) (where ? means that the same type of Bounds is returned -- Range or Bounds -- as the original.) The original AbstractBounds must contain the token T.
split(Token) - Method in class org.apache.cassandra.utils.MerkleTree
Splits the range containing the given token, if no tree limits would be violated.
SSLFactory - Class in org.apache.cassandra.security
A Factory for providing and setting up Client and Server SSL wrapped Socket and ServerSocket
SSLFactory() - Constructor for class org.apache.cassandra.security.SSLFactory
 
SSLFileStreamTask - Class in org.apache.cassandra.security.streaming
This class uses a DataOutputStream to write data as opposed to a FileChannel.transferTo used by FileStreamTask because the underlying SSLSocket doesn't support encrypting over NIO SocketChannel.
SSLFileStreamTask(StreamHeader, InetAddress) - Constructor for class org.apache.cassandra.security.streaming.SSLFileStreamTask
 
SSLIncomingStreamReader - Class in org.apache.cassandra.security.streaming
This class uses a DataInputStream to read data as opposed to a FileChannel.transferFrom used by IncomingStreamReader because the underlying SSLServerSocket doesn't support encrypting over NIO SocketChannel.
SSLIncomingStreamReader(StreamHeader, Socket, DataInputStream) - Constructor for class org.apache.cassandra.security.streaming.SSLIncomingStreamReader
 
SSTable - Class in org.apache.cassandra.io.sstable
This class is built on top of the SequenceFile.
SSTable(Descriptor, CFMetaData, ReplayPosition, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
 
SSTable(Descriptor, Set<Component>, CFMetaData, ReplayPosition, IPartitioner) - Constructor for class org.apache.cassandra.io.sstable.SSTable
 
SSTable(Descriptor, Set<Component>, CFMetaData, ReplayPosition, IPartitioner, EstimatedHistogram, EstimatedHistogram) - Constructor for class org.apache.cassandra.io.sstable.SSTable
 
sstable - Variable in class org.apache.cassandra.io.sstable.SSTableScanner
 
SSTableBoundedScanner - Class in org.apache.cassandra.io.sstable
A SSTableScanner that only reads key in a given range (for validation compaction).
SSTableBoundedScanner.BoundedKeyScanningIterator - Class in org.apache.cassandra.io.sstable
 
SSTableBoundedScanner.BoundedKeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.SSTableBoundedScanner.BoundedKeyScanningIterator
 
SSTableDeletingReference - Class in org.apache.cassandra.io.sstable
 
SSTableExport - Class in org.apache.cassandra.tools
Export SSTables to JSON format.
SSTableExport() - Constructor for class org.apache.cassandra.tools.SSTableExport
 
SSTableIdentityIterator - Class in org.apache.cassandra.io.sstable
 
SSTableIdentityIterator(SSTableReader, BufferedRandomAccessFile, DecoratedKey, long, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used to iterate through the columns of a row.
SSTableIdentityIterator(SSTableReader, BufferedRandomAccessFile, DecoratedKey, long, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
Used to iterate through the columns of a row.
SSTableIdentityIterator(CFMetaData, BufferedRandomAccessFile, DecoratedKey, long, long, boolean) - Constructor for class org.apache.cassandra.io.sstable.SSTableIdentityIterator
 
SSTableImport - Class in org.apache.cassandra.tools
Create SSTables from JSON input
SSTableImport() - Constructor for class org.apache.cassandra.tools.SSTableImport
 
SSTableNamesIterator - Class in org.apache.cassandra.db.columniterator
 
SSTableNamesIterator(SSTableReader, DecoratedKey, SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
SSTableNamesIterator(SSTableReader, FileDataInput, DecoratedKey, SortedSet<ByteBuffer>) - Constructor for class org.apache.cassandra.db.columniterator.SSTableNamesIterator
 
SSTableReader - Class in org.apache.cassandra.io.sstable
SSTableReaders are open()ed by Table.onStart; after that they are created by SSTableWriter.renameAndOpen.
SSTableReader.Operator - Class in org.apache.cassandra.io.sstable
TODO: Move someplace reusable
SSTableReader.Operator() - Constructor for class org.apache.cassandra.io.sstable.SSTableReader.Operator
 
SSTableScanner - Class in org.apache.cassandra.io.sstable
 
SSTableScanner.KeyScanningIterator - Class in org.apache.cassandra.io.sstable
 
SSTableScanner.KeyScanningIterator() - Constructor for class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
SSTableSliceIterator - Class in org.apache.cassandra.db.columniterator
A Column Iterator over SSTable
SSTableSliceIterator(SSTableReader, DecoratedKey, ByteBuffer, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
 
SSTableSliceIterator(SSTableReader, FileDataInput, DecoratedKey, ByteBuffer, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.db.columniterator.SSTableSliceIterator
An iterator for a slice within an SSTable
SSTableWriter - Class in org.apache.cassandra.io.sstable
 
SSTableWriter(String, long) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
 
SSTableWriter(String, long, CFMetaData, IPartitioner, ReplayPosition) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter
 
SSTableWriter.Builder - Class in org.apache.cassandra.io.sstable
Removes the given SSTable from temporary status and opens it, rebuilding the bloom filter and row index from the data file.
SSTableWriter.Builder(Descriptor, OperationType) - Constructor for class org.apache.cassandra.io.sstable.SSTableWriter.Builder
 
Stage - Enum in org.apache.cassandra.concurrent
 
StageManager - Class in org.apache.cassandra.concurrent
This class manages executor services for Messages recieved: each Message requests running on a specific "stage" for concurrency control; hence the Map approach, even though stages (executors) are not created dynamically.
StageManager() - Constructor for class org.apache.cassandra.concurrent.StageManager
 
start - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
start - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
start(int) - Method in class org.apache.cassandra.gms.Gossiper
Start the gossiper with the generation # retrieved from the System table
start() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized via AbstractCassandraDaemon.init(String[]) Hook for JSVC
start() - Method in interface org.apache.cassandra.service.CassandraDaemon
Start the Cassandra Daemon, assuming that it has already been initialized, via either CassandraDaemon.init(String[]) or #load(String[]).
start() - Method in class org.apache.cassandra.service.EmbeddedCassandraService
 
start() - Method in class org.apache.cassandra.service.GCInspector
 
startBroadcasting() - Method in class org.apache.cassandra.service.StorageLoadBalancer
 
startGossiping() - Method in class org.apache.cassandra.service.StorageService
 
startGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
startGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
 
startKey() - Method in class org.apache.cassandra.cli.CliParser
 
startNext() - Method in class org.apache.cassandra.streaming.StreamOutSession
 
startRPCServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Start the underlying RPC server in idempotent manner.
startRPCServer() - Method in interface org.apache.cassandra.service.CassandraDaemon
 
startRPCServer() - Method in class org.apache.cassandra.service.StorageService
 
startRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
startServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Start the underlying RPC server.
startServer() - Method in class org.apache.cassandra.thrift.CassandraDaemon
 
startThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
startTime - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
state() - Method in class org.apache.cassandra.thrift.CassandraServer
 
statement() - Method in class org.apache.cassandra.cli.CliParser
 
statement - Variable in class org.apache.cassandra.cql.CQLStatement
 
StatementType - Enum in org.apache.cassandra.cql
 
STATS - Static variable in class org.apache.cassandra.io.sstable.Component
 
STATUS_BOOTSTRAPPING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
STATUS_LEAVING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_LEFT - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_MOVING - Static variable in class org.apache.cassandra.gms.VersionedValue
 
STATUS_NORMAL - Static variable in class org.apache.cassandra.gms.VersionedValue
 
StatusCf - Static variable in class org.apache.cassandra.config.CFMetaData
 
StatusLogger - Class in org.apache.cassandra.utils
 
StatusLogger() - Constructor for class org.apache.cassandra.utils.StatusLogger
 
stdev() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
stop() - Method in class org.apache.cassandra.gms.Gossiper
 
stop() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the daemon, ideally in an idempotent manner.
stop() - Method in interface org.apache.cassandra.service.CassandraDaemon
Stop the daemon, ideally in an idempotent manner.
stop() - Method in class org.apache.cassandra.thrift.CustomTThreadPoolServer
 
stopClient() - Method in class org.apache.cassandra.service.StorageService
 
stopGossiping() - Method in class org.apache.cassandra.service.StorageService
 
stopGossiping() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopGossiping() - Method in class org.apache.cassandra.tools.NodeProbe
 
stopRPCServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the underlying RPC server in idempotent manner.
stopRPCServer() - Method in interface org.apache.cassandra.service.CassandraDaemon
 
stopRPCServer() - Method in class org.apache.cassandra.service.StorageService
 
stopRPCServer() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
stopServer() - Method in class org.apache.cassandra.service.AbstractCassandraDaemon
Stop the underlying RPC server.
stopServer() - Method in class org.apache.cassandra.thrift.CassandraDaemon
 
stopThriftServer() - Method in class org.apache.cassandra.tools.NodeProbe
 
storage_port - Variable in class org.apache.cassandra.config.Config
 
StorageLoadBalancer - Class in org.apache.cassandra.service
 
StorageProxy - Class in org.apache.cassandra.service
 
StorageProxyMBean - Interface in org.apache.cassandra.service
 
StorageService - Class in org.apache.cassandra.service
 
StorageService() - Constructor for class org.apache.cassandra.service.StorageService
 
StorageService.Verb - Enum in org.apache.cassandra.service
 
StorageServiceMBean - Interface in org.apache.cassandra.service
 
strategy_class - Variable in class org.apache.cassandra.config.ReplicationStrategy
 
strategy_class - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
strategy_options - Variable in class org.apache.cassandra.config.ReplicationStrategy
 
strategy_options - Variable in class org.apache.cassandra.db.migration.avro.KsDef
 
strategyClass - Variable in class org.apache.cassandra.config.KSMetaData
 
strategyOptions - Variable in class org.apache.cassandra.config.KSMetaData
 
stream(StreamHeader, InetAddress) - Method in class org.apache.cassandra.net.MessagingService
Stream a file from source to destination.
StreamHeader - Class in org.apache.cassandra.streaming
 
StreamHeader(String, long, PendingFile) - Constructor for class org.apache.cassandra.streaming.StreamHeader
 
StreamHeader(String, long, PendingFile, Collection<PendingFile>) - Constructor for class org.apache.cassandra.streaming.StreamHeader
 
StreamIn - Class in org.apache.cassandra.streaming
for streaming data from other nodes in to this one.
StreamIn() - Constructor for class org.apache.cassandra.streaming.StreamIn
 
StreamingService - Class in org.apache.cassandra.streaming
 
StreamingServiceMBean - Interface in org.apache.cassandra.streaming
 
StreamInSession - Class in org.apache.cassandra.streaming
each context gets its own StreamInSession.
StreamOut - Class in org.apache.cassandra.streaming
This class handles streaming data from one node to another.
StreamOut() - Constructor for class org.apache.cassandra.streaming.StreamOut
 
StreamOutSession - Class in org.apache.cassandra.streaming
This class manages the streaming of multiple files one after the other.
StreamReplyVerbHandler - Class in org.apache.cassandra.streaming
 
StreamReplyVerbHandler() - Constructor for class org.apache.cassandra.streaming.StreamReplyVerbHandler
 
StreamRequestVerbHandler - Class in org.apache.cassandra.streaming
This verb handler handles the StreamRequestMessage that is sent by the node requesting range transfer.
StreamRequestVerbHandler() - Constructor for class org.apache.cassandra.streaming.StreamRequestVerbHandler
 
string(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
string(ByteBuffer, int, int) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
string(ByteBuffer, int, int, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
string(ByteBuffer, Charset) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Decode a String representation.
STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlLexer
 
STRING_LITERAL - Static variable in class org.apache.cassandra.cql.CqlParser
 
stringifyFileSize(double) - Static method in class org.apache.cassandra.io.util.FileUtils
 
StringLiteral - Static variable in class org.apache.cassandra.cli.CliLexer
 
StringLiteral - Static variable in class org.apache.cassandra.cli.CliParser
 
StringToken - Class in org.apache.cassandra.dht
 
StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
 
subcolumnComparator - Variable in class org.apache.cassandra.config.CFMetaData
 
subcomparator_type - Variable in class org.apache.cassandra.db.migration.avro.CfDef
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.AddColumnFamily
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.Migration
Deflate this Migration into an Avro object.
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateColumnFamily
 
subdeflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateKeyspace
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.AddColumnFamily
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.Migration
Inflate this Migration from an Avro object: called after the required no-arg constructor.
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateColumnFamily
 
subinflate(Migration) - Method in class org.apache.cassandra.db.migration.UpdateKeyspace
 
subMap(ByteBuffer, ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
submit(Callable<T>) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Submits a value-returning task for execution and returns a Future representing the pending results of the task.
submit(Runnable, T) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Runnable) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Submits a Runnable task for execution and returns a Future representing that task.
submit(Callable<T>) - Method in interface org.apache.cassandra.db.commitlog.ICommitLogExecutorService
 
submitCacheWrite(AutoSavingCache.Writer) - Method in class org.apache.cassandra.db.CompactionManager
 
submitIndexBuild(ColumnFamilyStore, Table.IndexBuilder) - Method in class org.apache.cassandra.db.CompactionManager
Is not scheduled, because it is performing disjoint work from sstable compaction.
submitMajor(ColumnFamilyStore, long, int) - Method in class org.apache.cassandra.db.CompactionManager
 
submitMinorIfNeeded(ColumnFamilyStore) - Method in class org.apache.cassandra.db.CompactionManager
Call this whenever a compaction might be needed on the given columnfamily.
submitSSTableBuild(Descriptor, OperationType) - Method in class org.apache.cassandra.db.CompactionManager
Submits an sstable to be rebuilt: is not scheduled, since the sstable must not exist.
submitUserDefined(ColumnFamilyStore, Collection<Descriptor>, int) - Method in class org.apache.cassandra.db.CompactionManager
 
submitValidation(ColumnFamilyStore, AntiEntropyService.Validator) - Method in class org.apache.cassandra.db.CompactionManager
Does not mutate data, so is not scheduled.
submitWrite() - Method in class org.apache.cassandra.cache.AutoSavingCache
 
subsnitch - Variable in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
success - Variable in class org.apache.cassandra.db.TruncateResponse
 
sum() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
sumOfDeviations() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
super_column - Variable in class org.apache.cassandra.db.RangeSliceCommand
 
SuperColumn - Class in org.apache.cassandra.db
 
SuperColumn(ByteBuffer, AbstractType) - Constructor for class org.apache.cassandra.db.SuperColumn
 
superColumnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
switchMemtable() - Method in class org.apache.cassandra.db.DataTracker
Switch the current memtable.
sync() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
sync() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
system_add_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_add_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_drop_column_family(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_drop_keyspace(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
SYSTEM_TABLE - Static variable in class org.apache.cassandra.db.Table
 
system_update_column_family(CfDef) - Method in class org.apache.cassandra.thrift.CassandraServer
 
system_update_keyspace(KsDef) - Method in class org.apache.cassandra.thrift.CassandraServer
update an existing keyspace, but do not allow column family modifications.
SystemTable - Class in org.apache.cassandra.db
 
SystemTable() - Constructor for class org.apache.cassandra.db.SystemTable
 

T

T - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__100 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__100 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__101 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__101 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__102 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__102 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__103 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__103 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__104 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__104 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__105 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__105 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__106 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__106 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__107 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__107 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__108 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__108 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__109 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__109 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__110 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__110 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__111 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__111 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__112 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__112 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__113 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__113 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__114 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__114 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__115 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__115 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__116 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__116 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__117 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__117 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__75 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__75 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__76 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__76 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__77 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__77 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__78 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__78 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__79 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__79 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__80 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__80 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__81 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__81 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__82 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__82 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__83 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__83 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__84 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__84 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__85 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__85 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__86 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__86 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__87 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__87 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__88 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__88 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__89 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__89 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__90 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__90 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__91 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__91 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__92 - Static variable in class org.apache.cassandra.cql.CqlLexer
 
T__92 - Static variable in class org.apache.cassandra.cql.CqlParser
 
T__98 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__98 - Static variable in class org.apache.cassandra.cli.CliParser
 
T__99 - Static variable in class org.apache.cassandra.cli.CliLexer
 
T__99 - Static variable in class org.apache.cassandra.cli.CliParser
 
table - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
table - Variable in class org.apache.cassandra.db.ReadCommand
 
Table - Class in org.apache.cassandra.db
 
table() - Method in class org.apache.cassandra.db.WriteResponse
 
table - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
table - Variable in class org.apache.cassandra.service.AbstractRowResolver
 
table - Variable in class org.apache.cassandra.streaming.StreamHeader
 
table - Variable in class org.apache.cassandra.streaming.StreamOutSession
 
Table.IndexBuilder - Class in org.apache.cassandra.db
 
Table.IndexBuilder(ColumnFamilyStore, SortedSet<ByteBuffer>, ReducingKeyIterator) - Constructor for class org.apache.cassandra.db.Table.IndexBuilder
 
tableName - Variable in class org.apache.cassandra.cache.AutoSavingCache
 
tailMap(ByteBuffer) - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
takeSnapshot(String, String...) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot for the given tables.
takeSnapshot(String, String...) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes the snapshot for the given tables.
takeSnapshot(String, String...) - Method in class org.apache.cassandra.tools.NodeProbe
Take a snapshot of all the tables.
TASK_ID - Static variable in class org.apache.cassandra.net.HeaderTypes
 
TASK_PROFILE_CHAIN - Static variable in class org.apache.cassandra.net.HeaderTypes
 
tasks - Static variable in class org.apache.cassandra.service.StorageService
This pool is used by tasks that can have longer execution times, and usually are non periodic.
TBinaryProtocol - Class in org.apache.cassandra.thrift
TODO This was added to support writeBinary on direct buffers for CASSANDRA-1714; we can remove it once we upgrade to Thrift 0.7, which incorporates the patch (THRIFT-883).
TBinaryProtocol(TTransport) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol
 
TBinaryProtocol(TTransport, boolean, boolean) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol
 
TBinaryProtocol.Factory - Class in org.apache.cassandra.thrift
 
TBinaryProtocol.Factory() - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TBinaryProtocol.Factory(boolean, boolean) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TBinaryProtocol.Factory(boolean, boolean, int) - Constructor for class org.apache.cassandra.thrift.TBinaryProtocol.Factory
 
TCustomServerSocket - Class in org.apache.cassandra.thrift
Extends Thrift's TServerSocket to allow customization of various desirable TCP properties.
TCustomServerSocket(InetSocketAddress, boolean, Integer, Integer) - Constructor for class org.apache.cassandra.thrift.TCustomServerSocket
Allows fine-tuning of the server socket including keep-alive, reuse of addresses, send and receive buffer sizes.
TEMPFILE_MARKER - Static variable in class org.apache.cassandra.io.sstable.SSTable
 
temporary - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
term() - Method in class org.apache.cassandra.cql.CqlParser
 
Term - Class in org.apache.cassandra.cql
A term parsed from a CQL statement.
Term(String, int) - Constructor for class org.apache.cassandra.cql.Term
Create new Term instance from a string, and an integer that corresponds with the token ID from CQLParser.
Term(String, TermType) - Constructor for class org.apache.cassandra.cql.Term
 
Term() - Constructor for class org.apache.cassandra.cql.Term
 
termList() - Method in class org.apache.cassandra.cql.CqlParser
 
termPair(Map<Term, Term>) - Method in class org.apache.cassandra.cql.CqlParser
 
threadLocalMD5Digest() - Static method in class org.apache.cassandra.utils.FBUtilities
 
thrift_framed_transport_size_in_mb - Variable in class org.apache.cassandra.config.Config
 
thrift_max_message_length_in_mb - Variable in class org.apache.cassandra.config.Config
 
thriftifyColumns(Collection<IColumn>, boolean) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftifyCounterSubColumns(Collection<IColumn>) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftifySubColumns(Collection<IColumn>) - Method in class org.apache.cassandra.thrift.CassandraServer
 
thriftPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
ThriftValidation - Class in org.apache.cassandra.thrift
This has a lot of building blocks for CassandraServer to call to make sure it has valid input -- ensuring column names conform to the declared comparator, for instance.
ThriftValidation() - Constructor for class org.apache.cassandra.thrift.ThriftValidation
 
throttle_limit - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlLexer
 
throwLastRecognitionError() - Method in class org.apache.cassandra.cql.CqlParser
 
timestamp - Variable in class org.apache.cassandra.db.Column
 
timestamp() - Method in class org.apache.cassandra.db.Column
 
timestamp() - Method in interface org.apache.cassandra.db.IColumn
 
timestamp() - Method in class org.apache.cassandra.db.SuperColumn
 
timestamp - Variable in class org.apache.cassandra.utils.NodeId.NodeIdRecord
 
timestampMicros() - Static method in class org.apache.cassandra.utils.FBUtilities
 
timestampOfLastDelete() - Method in class org.apache.cassandra.db.CounterColumn
 
TimeUUIDType - Class in org.apache.cassandra.db.marshal
 
to - Variable in class org.apache.cassandra.streaming.FileStreamTask
 
toByteArray(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toByteArray(int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toByteArray(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toDouble(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toFloat(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toInt(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
Convert a byte buffer to an integer.
token - Variable in class org.apache.cassandra.db.DecoratedKey
 
token - Variable in class org.apache.cassandra.dht.BootStrapper
 
Token<T> - Class in org.apache.cassandra.dht
 
Token(T) - Constructor for class org.apache.cassandra.dht.Token
 
token - Variable in class org.apache.cassandra.dht.Token
 
token - Variable in class org.apache.cassandra.utils.MerkleTree.RowHash
 
Token.TokenFactory<T> - Class in org.apache.cassandra.dht
 
Token.TokenFactory() - Constructor for class org.apache.cassandra.dht.Token.TokenFactory
 
Token.TokenSerializer - Class in org.apache.cassandra.dht
 
Token.TokenSerializer() - Constructor for class org.apache.cassandra.dht.Token.TokenSerializer
 
tokenMetadata - Variable in class org.apache.cassandra.dht.BootStrapper
 
TokenMetadata - Class in org.apache.cassandra.locator
 
TokenMetadata() - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
TokenMetadata(BiMap<Token, InetAddress>) - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
tokenNames - Static variable in class org.apache.cassandra.cli.CliParser
 
tokenNames - Static variable in class org.apache.cassandra.cql.CqlParser
 
toLong(ByteBuffer) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
toString() - Method in class org.apache.cassandra.auth.AuthenticatedUser
 
toString(List<Object>) - Static method in class org.apache.cassandra.auth.Resources
 
toString() - Method in class org.apache.cassandra.config.CFMetaData
 
toString() - Method in class org.apache.cassandra.config.ColumnDefinition
 
toString() - Method in class org.apache.cassandra.config.KSMetaData
 
toString() - Method in class org.apache.cassandra.cql.BatchUpdateStatement
 
toString() - Method in class org.apache.cassandra.cql.DeleteStatement
 
toString() - Method in class org.apache.cassandra.cql.Relation
 
toString() - Method in class org.apache.cassandra.cql.Term
 
toString() - Method in class org.apache.cassandra.cql.UpdateStatement
 
toString() - Method in class org.apache.cassandra.db.ColumnFamily
 
toString() - Method in enum org.apache.cassandra.db.ColumnFamilyStore.CacheType
 
toString() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
toString() - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
toString() - Method in class org.apache.cassandra.db.commitlog.ReplayPosition
 
toString(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Human-readable String from context.
toString(ByteBuffer) - Method in interface org.apache.cassandra.db.context.IContext
Human-readable String from context.
toString() - Method in class org.apache.cassandra.db.CounterMutation
 
toString(boolean) - Method in class org.apache.cassandra.db.CounterMutation
 
toString() - Method in class org.apache.cassandra.db.DecoratedKey
 
toString() - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
toString() - Method in class org.apache.cassandra.db.filter.QueryFilter
 
toString() - Method in class org.apache.cassandra.db.filter.QueryPath
 
toString() - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
toString(boolean) - Method in interface org.apache.cassandra.db.IMutation
 
toString(T) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a string representation of a particular type.
toString(String) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
toString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
toString(Long) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
toString(BigInteger) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
toString(UUID) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
toString(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
toString(Long) - Method in class org.apache.cassandra.db.marshal.LongType
 
toString(UUID) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
toString(String) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
toString(UUID) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
toString() - Method in class org.apache.cassandra.db.Memtable
 
toString() - Method in class org.apache.cassandra.db.migration.AddColumnFamily
 
toString() - Method in class org.apache.cassandra.db.migration.AddKeyspace
 
toString() - Method in class org.apache.cassandra.db.migration.DropColumnFamily
 
toString() - Method in class org.apache.cassandra.db.migration.DropKeyspace
 
toString() - Method in class org.apache.cassandra.db.migration.RenameColumnFamily
Deprecated.  
toString() - Method in class org.apache.cassandra.db.migration.RenameKeyspace
Deprecated.  
toString() - Method in class org.apache.cassandra.db.migration.UpdateColumnFamily
 
toString() - Method in class org.apache.cassandra.db.migration.UpdateKeyspace
 
toString() - Method in class org.apache.cassandra.db.RangeSliceCommand
 
toString() - Method in class org.apache.cassandra.db.RangeSliceReply
 
toString() - Method in class org.apache.cassandra.db.Row
 
toString() - Method in class org.apache.cassandra.db.RowMutation
 
toString(boolean) - Method in class org.apache.cassandra.db.RowMutation
 
toString() - Method in class org.apache.cassandra.db.SliceByNamesReadCommand
 
toString() - Method in class org.apache.cassandra.db.SliceFromReadCommand
 
toString() - Method in class org.apache.cassandra.db.Table
 
toString() - Method in class org.apache.cassandra.db.Truncation
 
toString() - Method in class org.apache.cassandra.dht.Bounds
 
toString() - Method in class org.apache.cassandra.dht.BytesToken
 
toString() - Method in class org.apache.cassandra.dht.LocalToken
 
toString() - Method in class org.apache.cassandra.dht.Range
 
toString(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toString() - Method in class org.apache.cassandra.dht.Token
 
toString() - Method in class org.apache.cassandra.gms.FailureDetector
 
toString() - Method in class org.apache.cassandra.gms.GossipDigest
 
toString() - Method in class org.apache.cassandra.gms.VersionedValue
 
toString() - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
toString() - Method in class org.apache.cassandra.io.CompactionInfo
 
toString() - Method in class org.apache.cassandra.io.CompactionIterator
 
toString() - Method in enum org.apache.cassandra.io.CompactionType
 
toString() - Method in class org.apache.cassandra.io.sstable.Component
 
toString() - Method in class org.apache.cassandra.io.sstable.Descriptor
 
toString() - Method in class org.apache.cassandra.io.sstable.IndexSummary.KeyPosition
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTable
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTableScanner.KeyScanningIterator
 
toString() - Method in class org.apache.cassandra.io.sstable.SSTableScanner
 
toString() - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
toString() - Method in class org.apache.cassandra.io.util.MappedFileDataInput
 
toString() - Method in class org.apache.cassandra.io.util.SegmentedFile
 
toString() - Method in class org.apache.cassandra.locator.TokenMetadata
 
toString() - Method in class org.apache.cassandra.net.Message
 
toString() - Method in class org.apache.cassandra.service.AntiEntropyService.Differencer
 
toString() - Method in class org.apache.cassandra.service.AntiEntropyService.TreeRequest
 
toString() - Method in class org.apache.cassandra.streaming.PendingFile
 
toString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toString() - Method in class org.apache.cassandra.utils.LegacyBloomFilter
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.RowHash
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree
 
toString() - Method in class org.apache.cassandra.utils.MerkleTree.TreeRange
 
toString() - Method in class org.apache.cassandra.utils.NodeId
 
toString() - Method in class org.apache.cassandra.utils.Pair
 
total(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Returns the aggregated count across all node ids.
total() - Method in class org.apache.cassandra.db.CounterColumn
 
toThrift(KSMetaData) - Static method in class org.apache.cassandra.config.KSMetaData
 
toUTF8Bytes(UUID) - Static method in class org.apache.cassandra.db.migration.Migration
 
transferRanges(InetAddress, String, Collection<Range>, Runnable, OperationType) - Static method in class org.apache.cassandra.streaming.StreamOut
Split out files for all tables on disk locally for each range and then stream them to the target endpoint.
transferRangesForRequest(StreamOutSession, Collection<Range>, OperationType) - Static method in class org.apache.cassandra.streaming.StreamOut
Split out files for all tables on disk locally for each range and then stream them to the target endpoint.
transferSSTables(StreamOutSession, Collection<SSTableReader>, Collection<Range>, OperationType) - Static method in class org.apache.cassandra.streaming.StreamOut
Transfers matching portions of a group of sstables from a single table to the target endpoint.
translateKey(K) - Method in class org.apache.cassandra.cache.AutoSavingCache
 
translateKey(K) - Method in class org.apache.cassandra.cache.AutoSavingKeyCache
 
translateKey(K) - Method in class org.apache.cassandra.cache.AutoSavingRowCache
 
tree - Variable in class org.apache.cassandra.service.AntiEntropyService.Validator
 
trimTrailingZeros() - Method in class org.apache.cassandra.utils.obs.OpenBitSet
Lowers numWords, the number of words in use, by checking for trailing zero words.
TRUNCATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
TRUNCATE - Static variable in class org.apache.cassandra.cli.CliParser
 
truncate() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Truncate practically deletes the entire column family's data
truncate(String) - Method in class org.apache.cassandra.db.Table
Performs a synchronous truncate operation, effectively deleting all data from the column family cfname
truncate(String, long) - Static method in class org.apache.cassandra.io.util.FileUtils
 
truncate(String, String) - Method in class org.apache.cassandra.service.StorageService
 
truncate(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Truncates (deletes) the given columnFamily from the provided keyspace.
truncate(String) - Method in class org.apache.cassandra.thrift.CassandraServer
 
truncate(String, String) - Method in class org.apache.cassandra.tools.NodeProbe
 
truncateBlocking(String, String) - Static method in class org.apache.cassandra.service.StorageProxy
Performs the truncate operatoin, which effectively deletes all data from the column family cfname
TruncateResponse - Class in org.apache.cassandra.db
This message is sent back the truncate operation and basically specifies if the truncate succeeded.
TruncateResponse(String, String, boolean) - Constructor for class org.apache.cassandra.db.TruncateResponse
 
TruncateResponse.TruncateResponseSerializer - Class in org.apache.cassandra.db
 
TruncateResponse.TruncateResponseSerializer() - Constructor for class org.apache.cassandra.db.TruncateResponse.TruncateResponseSerializer
 
TruncateResponseHandler - Class in org.apache.cassandra.service
 
TruncateResponseHandler(int) - Constructor for class org.apache.cassandra.service.TruncateResponseHandler
 
truncateStatement() - Method in class org.apache.cassandra.cli.CliParser
 
truncateStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
TruncateVerbHandler - Class in org.apache.cassandra.db
Handles the TRUNCATE verb
TruncateVerbHandler() - Constructor for class org.apache.cassandra.db.TruncateVerbHandler
 
Truncation - Class in org.apache.cassandra.db
A truncate operation descriptor
Truncation(String, String) - Constructor for class org.apache.cassandra.db.Truncation
 
truststore - Variable in class org.apache.cassandra.config.EncryptionOptions
 
truststore_password - Variable in class org.apache.cassandra.config.EncryptionOptions
 
tryComponentFromFilename(File, String) - Static method in class org.apache.cassandra.io.sstable.SSTable
 
tryFcntl(int, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
tryMlockall() - Static method in class org.apache.cassandra.utils.CLibrary
 
trySkipCache(int, int, int) - Static method in class org.apache.cassandra.utils.CLibrary
 
tsSize_ - Static variable in class org.apache.cassandra.db.DBConstants
 
TTL - Static variable in class org.apache.cassandra.cli.CliLexer
 
TTL - Static variable in class org.apache.cassandra.cli.CliParser
 
TWO - Static variable in class org.apache.cassandra.utils.FBUtilities
 
type - Variable in class org.apache.cassandra.cql.CQLStatement
 
type - Variable in class org.apache.cassandra.io.CompactionIterator
 
type - Variable in class org.apache.cassandra.io.sstable.Component
 
type - Variable in class org.apache.cassandra.streaming.PendingFile
 
TypedColumn - Class in org.apache.cassandra.cql.jdbc
 
TypedColumn(Column, AbstractType, AbstractType) - Constructor for class org.apache.cassandra.cql.jdbc.TypedColumn
 
typeIdentifier() - Method in class org.apache.cassandra.cli.CliParser
 

U

U - Static variable in class org.apache.cassandra.cql.CqlLexer
 
U - Static variable in class org.apache.cassandra.cql.CqlParser
 
unescapeSQLString(String) - Static method in class org.apache.cassandra.cli.CliUtils
Strips leading and trailing "'" characters, and handles and escaped characters such as \n, \r, etc.
UnicodeEscapeSequence - Static variable in class org.apache.cassandra.cli.CliLexer
 
UnicodeEscapeSequence - Static variable in class org.apache.cassandra.cli.CliParser
 
union(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
this = this OR other
unionCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of the union of the two sets.
unmarkCompacting(Collection<SSTableReader>) - Method in class org.apache.cassandra.db.DataTracker
Removes files from compacting status: this is different from 'markCompacted' because it should be run regardless of whether a compaction succeeded.
UNREACHABLE - Static variable in class org.apache.cassandra.service.StorageProxy
 
unregister(IEndpointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
Unregister interest for state changes.
unregister(AbstractReplicationStrategy) - Method in class org.apache.cassandra.locator.TokenMetadata
 
unregisterFailureDetectionEventListener(IFailureDetectionEventListener) - Method in class org.apache.cassandra.gms.FailureDetector
 
unregisterFailureDetectionEventListener(IFailureDetectionEventListener) - Method in interface org.apache.cassandra.gms.IFailureDetector
Un-register interest for Failure Detector events.
unregisterMBean() - Method in class org.apache.cassandra.locator.DynamicEndpointSnitch
 
UnserializableColumnFamilyException - Exception in org.apache.cassandra.db
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
UnserializableColumnFamilyException(String, int) - Constructor for exception org.apache.cassandra.db.UnserializableColumnFamilyException
 
unwrap(Class<T>) - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
unwrap() - Method in class org.apache.cassandra.dht.AbstractBounds
 
unwrap() - Method in class org.apache.cassandra.dht.Bounds
 
unwrap() - Method in class org.apache.cassandra.dht.Range
 
UPDATE - Static variable in class org.apache.cassandra.cli.CliLexer
 
UPDATE - Static variable in class org.apache.cassandra.cli.CliParser
 
update(MessageDigest) - Method in class org.apache.cassandra.io.AbstractCompactedRow
update @param digest with the data bytes of the row (not including row key or row size)
update(MessageDigest) - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
update(MessageDigest) - Method in class org.apache.cassandra.io.PrecompactedRow
 
updateCacheSize(long) - Method in class org.apache.cassandra.cache.AutoSavingCache
Resizes the cache based on a key estimate.
updateCacheSizes() - Method in class org.apache.cassandra.db.ColumnFamilyStore
Resizes the key and row caches based on the current key estimate.
updateCapacity(int) - Method in class org.apache.cassandra.cache.InstrumentingCache
 
updateColumnFamily() - Method in class org.apache.cassandra.cli.CliParser
 
UpdateColumnFamily - Class in org.apache.cassandra.db.migration.avro
 
UpdateColumnFamily() - Constructor for class org.apache.cassandra.db.migration.avro.UpdateColumnFamily
 
UpdateColumnFamily - Class in org.apache.cassandra.db.migration
todo: doesn't work with secondary indices yet.
UpdateColumnFamily() - Constructor for class org.apache.cassandra.db.migration.UpdateColumnFamily
 
UpdateColumnFamily(CfDef) - Constructor for class org.apache.cassandra.db.migration.UpdateColumnFamily
assumes validation has already happened.
updateCompletor(Set<String>) - Static method in class org.apache.cassandra.cli.CliMain
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.Column
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ColumnFamily
 
updateDigest(MessageDigest, ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
Update a MessageDigest with the content of a context.
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.CounterColumn
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ExpiringColumn
 
updateDigest(MessageDigest) - Method in interface org.apache.cassandra.db.IColumn
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.SuperColumn
 
updateKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
UpdateKeyspace - Class in org.apache.cassandra.db.migration.avro
 
UpdateKeyspace() - Constructor for class org.apache.cassandra.db.migration.avro.UpdateKeyspace
 
UpdateKeyspace - Class in org.apache.cassandra.db.migration
Licensed to the Apache Software Foundation (ASF) under one or more contributor license agreements.
UpdateKeyspace() - Constructor for class org.apache.cassandra.db.migration.UpdateKeyspace
Required no-arg constructor
UpdateKeyspace(KSMetaData) - Constructor for class org.apache.cassandra.db.migration.UpdateKeyspace
create migration based on thrift parameters
updateLiveRatio() - Method in class org.apache.cassandra.db.Memtable
 
updateNormalToken(Token, InetAddress) - Method in class org.apache.cassandra.locator.TokenMetadata
 
updateRowCache(DecoratedKey, ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in class org.apache.cassandra.service.StorageService
 
updateSnitch(String, Boolean, Integer, Integer, Double) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Change endpointsnitch class and dynamic-ness (and dynamic attributes) at runtime
updateStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
UpdateStatement - Class in org.apache.cassandra.cql
An UPDATE statement parsed from a CQL query statement.
UpdateStatement(String, ConsistencyLevel, Map<Term, Term>, Term) - Constructor for class org.apache.cassandra.cql.UpdateStatement
Creates a new UpdateStatement from a column family name, columns map, consistency level, and key term.
UpdateStatement(String, Map<Term, Term>, Term) - Constructor for class org.apache.cassandra.cql.UpdateStatement
Creates a new UpdateStatement from a column family name, columns map, and key term.
UpdateStatement(String, ConsistencyLevel, List<Term>, List<Term>, Term) - Constructor for class org.apache.cassandra.cql.UpdateStatement
Creates a new UpdateStatement from a column family name, a consistency level, key, and lists of column names and values.
updateToken(InetAddress, Token) - Static method in class org.apache.cassandra.db.SystemTable
Record token being used by another node
updateToken(Token) - Static method in class org.apache.cassandra.db.SystemTable
This method is used to update the System Table with the new token for this node
USE - Static variable in class org.apache.cassandra.cli.CliLexer
 
USE - Static variable in class org.apache.cassandra.cli.CliParser
 
useEfficientCrossDCWrites() - Method in class org.apache.cassandra.service.StorageService
 
useKeyspace() - Method in class org.apache.cassandra.cli.CliParser
 
username - Variable in class org.apache.cassandra.auth.AuthenticatedUser
 
username() - Method in class org.apache.cassandra.cli.CliParser
 
username - Variable in class org.apache.cassandra.cli.CliSessionState
 
USERNAME_KEY - Static variable in class org.apache.cassandra.auth.SimpleAuthenticator
 
usesOldBloomFilter - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
useStatement() - Method in class org.apache.cassandra.cql.CqlParser
 
UTF8Type - Class in org.apache.cassandra.db.marshal
 
UUID - Static variable in class org.apache.cassandra.cql.CqlLexer
 
UUID - Static variable in class org.apache.cassandra.cql.CqlParser
 
UUID - Class in org.apache.cassandra.utils.avro
 
UUID() - Constructor for class org.apache.cassandra.utils.avro.UUID
 
UUIDGen - Class in org.apache.cassandra.utils
The goods are here: www.ietf.org/rfc/rfc4122.txt.
UUIDType - Class in org.apache.cassandra.db.marshal
Compares UUIDs using the following criteria:
- if count of supplied bytes is less than 16, compare counts
- compare UUID version fields
- nil UUID is always lesser
- compare timestamps if both are time-based
- compare lexically, unsigned msb-to-lsb comparison

V

V - Static variable in class org.apache.cassandra.cql.CqlLexer
 
V - Static variable in class org.apache.cassandra.cql.CqlParser
 
valid - Variable in class org.apache.cassandra.cache.FreeableMemory
 
validate() - Method in class org.apache.cassandra.cql.CreateKeyspaceStatement
The CqlParser only goes as far as extracting the keyword arguments from these statements, so this method is responsible for processing and validating, and must be called prior to access.
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AbstractType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.BytesType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.CounterColumnType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.IntegerType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LocalByPartionerType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.LongType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
validate(ByteBuffer) - Method in class org.apache.cassandra.db.marshal.UUIDType
 
validateCfDef(CfDef) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnData(CFMetaData, Column) - Static method in class org.apache.cassandra.thrift.ThriftValidation
Validates the data part of the column (everything in the Column object but the name)
validateColumnFamily(String, String, boolean) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnFamily(String, String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnFields() - Method in class org.apache.cassandra.db.ColumnFamily
Goes over all columns and check the fields are valid (as far as we can tell).
validateColumnNames(CFMetaData, ColumnParent, Iterable<ByteBuffer>) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnOrSuperColumn(CFMetaData, ColumnOrSuperColumn) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnParent(CFMetaData, ColumnParent) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateColumnPath(CFMetaData, ColumnPath) - Static method in class org.apache.cassandra.thrift.ThriftValidation
validates all parts of the path to the column, including the column name
validateCommutativeForWrite(CFMetaData, ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.AllowAllAuthority
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthenticator
 
validateConfiguration() - Method in interface org.apache.cassandra.auth.IAuthority
 
validateConfiguration() - Method in class org.apache.cassandra.auth.SimpleAuthenticator
 
validateConfiguration() - Method in class org.apache.cassandra.auth.SimpleAuthority
 
validateConsistencyLevel(String, ConsistencyLevel) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateContext(ByteBuffer) - Method in class org.apache.cassandra.db.context.CounterContext
 
validateCurrentFile(String) - Method in class org.apache.cassandra.streaming.StreamOutSession
 
validateDeletion(CFMetaData, Deletion) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.Column
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.CounterColumn
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.DeletedColumn
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.ExpiringColumn
 
validateFields(CFMetaData) - Method in interface org.apache.cassandra.db.IColumn
 
validateFields(CFMetaData) - Method in class org.apache.cassandra.db.SuperColumn
 
validateIndexClauses(CFMetaData, IndexClause) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateIndexType(ColumnDef) - Static method in class org.apache.cassandra.config.ColumnDefinition
 
validateKey(CFMetaData, ByteBuffer) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKeyRange(KeyRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateKsDef(KsDef) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateMagic(int) - Static method in class org.apache.cassandra.net.MessagingService
 
validateMemtableFlushPeriod(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
validateMemtableOperations(double) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
validateMemtableSettings(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
validateMemtableSettings(CfDef) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateMemtableThroughput(int) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
validateMinMaxCompactionThresholds(CfDef) - Static method in class org.apache.cassandra.config.CFMetaData
 
validateMinMaxCompactionThresholds(CfDef) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateMutation(CFMetaData, Mutation) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateName(CFMetaData) - Method in class org.apache.cassandra.db.Column
 
validateOptions() - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.LocalStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.NetworkTopologyStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.OldNetworkTopologyStrategy
 
validateOptions() - Method in class org.apache.cassandra.locator.SimpleStrategy
 
validatePredicate(CFMetaData, ColumnParent, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateRange(CFMetaData, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateReplicationFactor(String) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
validateSlicePredicate(CFMetaData, ByteBuffer, SlicePredicate) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validateTable(String) - Static method in class org.apache.cassandra.thrift.ThriftValidation
 
validation_class - Variable in class org.apache.cassandra.db.migration.avro.ColumnDef
 
value() - Method in class org.apache.cassandra.cli.CliParser
 
value - Variable in class org.apache.cassandra.db.Column
 
value() - Method in class org.apache.cassandra.db.Column
 
value() - Method in interface org.apache.cassandra.db.IColumn
 
value() - Method in class org.apache.cassandra.db.SuperColumn
 
value - Variable in class org.apache.cassandra.gms.VersionedValue
 
value() - Method in class org.apache.cassandra.utils.DefaultDouble
 
value() - Method in class org.apache.cassandra.utils.DefaultInteger
 
valueFactory - Variable in class org.apache.cassandra.service.StorageService
 
valueOf(String) - Static method in enum org.apache.cassandra.auth.Permission
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.auth.SimpleAuthenticator.PasswordMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.ColumnFamilyArgument
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cli.CliClient.Function
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.concurrent.Stage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.config.EncryptionOptions.InternodeEncryption
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.cql.StatementType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyStore.CacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.ColumnFamilyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.db.migration.avro.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.gms.ApplicationState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.io.CompactionType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.io.SerializerType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.service.StorageService.Verb
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.streaming.OperationType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.tools.NodeCmd.NodeCommand
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.cassandra.auth.Permission
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.auth.SimpleAuthenticator.PasswordMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cli.CliClient.ColumnFamilyArgument
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cli.CliClient.Function
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.concurrent.Stage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.CommitLogSync
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.DiskAccessMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.Config.RequestSchedulerId
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.config.EncryptionOptions.InternodeEncryption
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.cql.StatementType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.ColumnFamilyStore.CacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.ColumnFamilyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.context.IContext.ContextRelationship
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.db.migration.avro.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.gms.ApplicationState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.io.CompactionType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.io.util.ColumnSortedMap
 
values() - Static method in enum org.apache.cassandra.net.io.SerializerType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.service.StorageService.Verb
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.streaming.OperationType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.tools.NodeCmd.NodeCommand
Returns an array containing the constants of this enum type, in the order they are declared.
variance() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
verbose - Variable in class org.apache.cassandra.cli.CliSessionState
 
VERBS - Static variable in class org.apache.cassandra.service.StorageService
 
verbStages - Static variable in class org.apache.cassandra.service.StorageService
 
version - Variable in class org.apache.cassandra.gms.VersionedValue
 
version - Variable in class org.apache.cassandra.io.sstable.Descriptor
 
VERSION - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
version_ - Static variable in class org.apache.cassandra.net.MessagingService
 
version_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
VERSION_07 - Static variable in class org.apache.cassandra.net.MessagingService
 
VersionedValue - Class in org.apache.cassandra.gms
This abstraction represents the state associated with a particular node which an application wants to make available to the rest of the nodes in the cluster.
VersionedValue.VersionedValueFactory - Class in org.apache.cassandra.gms
 
VersionedValue.VersionedValueFactory(IPartitioner) - Constructor for class org.apache.cassandra.gms.VersionedValue.VersionedValueFactory
 
VersionGenerator - Class in org.apache.cassandra.gms
A unique version number generator for any state that is generated by the local node.
VersionGenerator() - Constructor for class org.apache.cassandra.gms.VersionGenerator
 

W

W - Static variable in class org.apache.cassandra.cql.CqlLexer
 
W - Static variable in class org.apache.cassandra.cql.CqlParser
 
waitFor() - Static method in class org.apache.cassandra.io.DeletionService
 
waitFor() - Method in class org.apache.cassandra.net.MessagingService
blocks until the processing pools are empty and done.
waitForLoadInfo() - Method in class org.apache.cassandra.service.StorageLoadBalancer
Wait for at least BROADCAST_INTERVAL ms, to give all nodes enough time to report in.
waitingFor(Message) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
waitingFor(ReadResponse) - Method in class org.apache.cassandra.service.DatacenterReadCallback
 
waitingFor(Message) - Method in class org.apache.cassandra.service.ReadCallback
 
waitingFor(ReadResponse) - Method in class org.apache.cassandra.service.ReadCallback
 
waitOnFutures(Iterable<Future<?>>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
waitUntilListening() - Method in class org.apache.cassandra.net.MessagingService
 
wasNull() - Method in class org.apache.cassandra.cql.jdbc.CResultSet
 
watch(String, Runnable, int) - Static method in class org.apache.cassandra.utils.ResourceWatcher
 
weights - Variable in class org.apache.cassandra.config.RequestSchedulerOptions
 
whereClause() - Method in class org.apache.cassandra.cql.CqlParser
 
WhereClause - Class in org.apache.cassandra.cql
WhereClauses encapsulate all of the predicates of a SELECT query.
WhereClause(Relation) - Constructor for class org.apache.cassandra.cql.WhereClause
Create a new WhereClause with the first parsed relation.
WhereClause() - Constructor for class org.apache.cassandra.cql.WhereClause
 
width - Variable in class org.apache.cassandra.io.sstable.IndexHelper.IndexInfo
 
WITH - Static variable in class org.apache.cassandra.cli.CliLexer
 
WITH - Static variable in class org.apache.cassandra.cli.CliParser
 
wlen - Variable in class org.apache.cassandra.utils.obs.OpenBitSet
 
wrap(ByteBuffer) - Static method in class org.apache.cassandra.utils.NodeId
 
wrap(ByteBuffer, int) - Static method in class org.apache.cassandra.utils.NodeId
 
WrappedRunnable - Class in org.apache.cassandra.utils
 
WrappedRunnable() - Constructor for class org.apache.cassandra.utils.WrappedRunnable
 
write(RowMutation) - Method in class org.apache.cassandra.db.commitlog.CommitLogSegment
 
write(DataOutput) - Method in class org.apache.cassandra.hadoop.ColumnFamilySplit
 
write(DataOutput) - Method in class org.apache.cassandra.io.AbstractCompactedRow
write the row (size + column index + filter + column data, but NOT row key) to @param out
write(DataOutput) - Method in class org.apache.cassandra.io.LazilyCompactedRow
 
write(DataOutput) - Method in class org.apache.cassandra.io.PrecompactedRow
 
write(int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
write(byte[]) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.util.BufferedRandomAccessFile
 
write(int) - Method in class org.apache.cassandra.io.util.MemoryOutputStream
 
write(DataInput, int) - Method in class org.apache.cassandra.io.util.OutputBuffer
 
write(ByteBuffer) - Method in class org.apache.cassandra.net.OutboundTcpConnection
 
write(FileChannel, Pair<Long, Long>, long, long) - Method in class org.apache.cassandra.security.streaming.SSLFileStreamTask
 
write(FileChannel, Pair<Long, Long>, long, long) - Method in class org.apache.cassandra.streaming.FileStreamTask
 
write(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeBinary(ByteBuffer) - Method in class org.apache.cassandra.thrift.TBinaryProtocol
 
writeCurrentLocalNodeId(NodeId, NodeId) - Static method in class org.apache.cassandra.db.SystemTable
Write a new current local node id to the system table.
writeElement(NodeId, long, long, boolean) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeElement(NodeId, long, long) - Method in class org.apache.cassandra.db.context.CounterContext.ContextState
 
writeEndpoints - Variable in class org.apache.cassandra.service.AbstractWriteResponseHandler
 
writeHeader(ByteBuffer) - Method in class org.apache.cassandra.security.streaming.SSLFileStreamTask
 
writeHeader(ByteBuffer) - Method in class org.apache.cassandra.streaming.FileStreamTask
 
WriteResponse - Class in org.apache.cassandra.db
 
WriteResponse(String, ByteBuffer, boolean) - Constructor for class org.apache.cassandra.db.WriteResponse
 
WriteResponse.WriteResponseSerializer - Class in org.apache.cassandra.db
 
WriteResponse.WriteResponseSerializer() - Constructor for class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
WriteResponseHandler - Class in org.apache.cassandra.service
Handles blocking writes for ONE, ANY, TWO, THREE, QUORUM, and ALL consistency levels.
WriteResponseHandler(Collection<InetAddress>, Multimap<InetAddress, InetAddress>, ConsistencyLevel, String) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
WriteResponseHandler(InetAddress) - Constructor for class org.apache.cassandra.service.WriteResponseHandler
 
writeWithLength(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
writeWithShortLength(ByteBuffer, DataOutput) - Static method in class org.apache.cassandra.utils.ByteBufferUtil
 
WS - Static variable in class org.apache.cassandra.cli.CliLexer
 
WS - Static variable in class org.apache.cassandra.cli.CliParser
 
WS - Static variable in class org.apache.cassandra.cql.CqlLexer
 
WS - Static variable in class org.apache.cassandra.cql.CqlParser
 

X

X - Static variable in class org.apache.cassandra.cql.CqlLexer
 
X - Static variable in class org.apache.cassandra.cql.CqlParser
 
XMLUtils - Class in org.apache.cassandra.utils
 
XMLUtils(String) - Constructor for class org.apache.cassandra.utils.XMLUtils
 
xor(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
xor(OpenBitSet) - Method in class org.apache.cassandra.utils.obs.OpenBitSet
this = this XOR other
xorCount(OpenBitSet, OpenBitSet) - Static method in class org.apache.cassandra.utils.obs.OpenBitSet
Returns the popcount or cardinality of the exclusive-or of the two sets.

Y

Y - Static variable in class org.apache.cassandra.cql.CqlLexer
 
Y - Static variable in class org.apache.cassandra.cql.CqlParser
 

Z

Z - Static variable in class org.apache.cassandra.cql.CqlLexer
 
Z - Static variable in class org.apache.cassandra.cql.CqlParser
 
ZERO - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 

A B C D E F G H I J K L M N O P Q R S T U V W X Y Z

Copyright © 2011 The Apache Software Foundation