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

A

AbstractColumnIterator - Class in org.apache.cassandra.db.filter
 
AbstractColumnIterator() - Constructor for class org.apache.cassandra.db.filter.AbstractColumnIterator
 
AbstractReplicationStrategy - Class in org.apache.cassandra.locator
This class contains a helper method that will be used by all abstraction that implement the IReplicaPlacementStrategy interface.
AbstractStatsDeque - Class in org.apache.cassandra.utils
 
AbstractStatsDeque() - Constructor for class org.apache.cassandra.utils.AbstractStatsDeque
 
AbstractType - Class in org.apache.cassandra.db.marshal
Specifies a Comparator for a specific type of byte[].
AbstractType() - Constructor for class org.apache.cassandra.db.marshal.AbstractType
 
accept(SelectionKey) - Method in class org.apache.cassandra.net.SelectionKeyHandler
Method which is called when the key becomes acceptable.
accept(SelectionKey) - Method in class org.apache.cassandra.net.TcpConnectionHandler
 
add(ColumnFamily) - Method in class org.apache.cassandra.db.RowMutation
 
add(QueryPath, byte[], long) - Method in class org.apache.cassandra.db.RowMutation
 
add(String, int) - Method in class org.apache.cassandra.db.Table.TableMetadata
 
add(String, int, String) - Method in class org.apache.cassandra.db.Table.TableMetadata
 
add(double) - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
add(String) - Method in class org.apache.cassandra.utils.BloomFilter
 
add(byte[]) - Method in class org.apache.cassandra.utils.BloomFilter
 
add(double) - Method in class org.apache.cassandra.utils.BoundedStatsDeque
 
add(String) - Method in class org.apache.cassandra.utils.Filter
 
add(double) - Method in class org.apache.cassandra.utils.TimedStatsDeque
 
addApplicationState(String, ApplicationState) - Method in class org.apache.cassandra.gms.Gossiper
 
addBootstrapSource(EndPoint) - Method in class org.apache.cassandra.service.StorageService
 
addColumn(IColumn) - Method in class org.apache.cassandra.db.Column
 
addColumn(QueryPath, byte[], long) - Method in class org.apache.cassandra.db.ColumnFamily
 
addColumn(QueryPath, byte[], long, boolean) - Method in class org.apache.cassandra.db.ColumnFamily
In most places the CF must be part of a QueryPath but here it is ignored.
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
 
addFilesToStream(StreamContextManager.StreamContext[]) - Method in class org.apache.cassandra.service.StreamManager
 
addHeader(String, byte[]) - Method in class org.apache.cassandra.net.Message
 
addMessageSink(IMessageSink) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
addStreamContext(String, StreamContextManager.StreamContext, StreamContextManager.StreamStatus) - Static method in class org.apache.cassandra.net.io.StreamContextManager
 
advance(boolean) - Method in class org.apache.cassandra.io.FileStruct
 
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
(non-Javadoc)
afterExecute(Runnable, Throwable) - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
AIOExecutorService - Class in org.apache.cassandra.concurrent
 
AIOExecutorService(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.AIOExecutorService
 
alwaysMatchingBloomFilter() - Static method in class org.apache.cassandra.utils.BloomFilter
 
append(String, DataOutputBuffer) - Method in class org.apache.cassandra.io.SSTableWriter
 
append(String, byte[]) - Method in class org.apache.cassandra.io.SSTableWriter
 
ApplicationState - 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.
ApplicationState(String) - Constructor for class org.apache.cassandra.gms.ApplicationState
Wraps the specified state into a ApplicationState instance.
apply() - Method in class org.apache.cassandra.db.RowMutation
 
AsciiType - Class in org.apache.cassandra.db.marshal
 
AsciiType() - Constructor for class org.apache.cassandra.db.marshal.AsciiType
 
attachContext(Object) - Method in interface org.apache.cassandra.net.IAsyncCallback
Attach some application specific context to the callback.
attachContext(Object) - Method in class org.apache.cassandra.service.MultiQuorumResponseHandler
The context that is passed in for the query of multiple keys in the system.
attachContext(Object) - Method in class org.apache.cassandra.service.QuorumResponseHandler
 
autoCompactionFactor_ - Variable in class org.apache.cassandra.utils.FastHash
The auto-compaction factor for the table.
autoCompactRemovesRemaining_ - Variable in class org.apache.cassandra.utils.FastHash
The number of removes that should be performed before an auto-compaction occurs.
available() - Method in class org.apache.cassandra.io.FastBufferedInputStream
Returns an estimate of the number of bytes that can be read (or skipped over) from this input stream without blocking by the next invocation of a method for this input stream.
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.CommitLogExecutorService
 

B

BasicUtilities - Class in org.apache.cassandra.utils
 
BasicUtilities() - Constructor for class org.apache.cassandra.utils.BasicUtilities
 
batch_insert(String, String, Map<String, List<ColumnOrSuperColumn>>, int) - Method in class org.apache.cassandra.service.CassandraServer
 
bf - Variable in class org.apache.cassandra.io.SSTable
 
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
 
BinaryMemtable - Class in org.apache.cassandra.db
 
BinaryVerbHandler - Class in org.apache.cassandra.db
 
BinaryVerbHandler() - Constructor for class org.apache.cassandra.db.BinaryVerbHandler
 
binaryVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
BitSetSerializer - Class in org.apache.cassandra.utils
 
BitSetSerializer() - Constructor for class org.apache.cassandra.utils.BitSetSerializer
 
BloomCalculations - Class in org.apache.cassandra.utils
The following calculations are taken from: http://www.cs.wisc.edu/~cao/papers/summary-cache/node8.html "Bloom Filters - the math" This class's static methods are meant to facilitate the use of the Bloom Filter class by helping to choose correct values of 'bits per element' and 'number of hash functions, k'.
BloomCalculations() - Constructor for class org.apache.cassandra.utils.BloomCalculations
 
BloomCalculations.BloomSpecification - Class in org.apache.cassandra.utils
A wrapper class that holds two key parameters for a Bloom Filter: the number of hash functions used, and the number of buckets per element used.
BloomCalculations.BloomSpecification(int, int) - Constructor for class org.apache.cassandra.utils.BloomCalculations.BloomSpecification
 
BloomFilter - Class in org.apache.cassandra.utils
 
BloomFilter(int, int) - Constructor for class org.apache.cassandra.utils.BloomFilter
 
BloomFilter(int, double) - Constructor for class org.apache.cassandra.utils.BloomFilter
 
booleanToByteArray(boolean) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
bootStrapInitiateDoneVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
BootstrapInitiateMessage - Class in org.apache.cassandra.dht
 
BootstrapInitiateMessage(StreamContextManager.StreamContext[]) - Constructor for class org.apache.cassandra.dht.BootstrapInitiateMessage
 
bootStrapInitiateVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
BootstrapMetadataVerbHandler - Class in org.apache.cassandra.dht
This verb handler handles the BootstrapMetadataMessage that is sent by the leader to the nodes that are responsible for handing off data.
BootstrapMetadataVerbHandler() - Constructor for class org.apache.cassandra.dht.BootstrapMetadataVerbHandler
 
bootStrapNodes(String) - Method in class org.apache.cassandra.tools.NodeProbe
Bootstrap the listed nodes with data
BootStrapper - Class in org.apache.cassandra.dht
This class handles the bootstrapping responsibilities for any new endpoint.
BootStrapper(EndPoint[], Token...) - Constructor for class org.apache.cassandra.dht.BootStrapper
 
bootStrapTerminateVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
BoundedStatsDeque - Class in org.apache.cassandra.utils
not threadsafe.
BoundedStatsDeque(int) - Constructor for class org.apache.cassandra.utils.BoundedStatsDeque
 
bsMetadataVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
buf - Variable in class org.apache.cassandra.io.FastBufferedInputStream
The internal buffer array where the data is stored.
buf - Variable in class org.apache.cassandra.io.FastBufferedOutputStream
The internal buffer where data is stored.
buffer_ - Variable in class org.apache.cassandra.db.RowMutationVerbHandler.RowMutationContext
 
BufferedRandomAccessFile - Class in org.apache.cassandra.io
A BufferedRandomAccessFile is like a RandomAccessFile, but it uses a private buffer so that most operations do not require a disk access.
BufferedRandomAccessFile(File, String) - Constructor for class org.apache.cassandra.io.BufferedRandomAccessFile
Open a new BufferedRandomAccessFile on file in mode mode, which should be "r" for reading only, or "rw" for reading and writing.
BufferedRandomAccessFile(File, String, int) - Constructor for class org.apache.cassandra.io.BufferedRandomAccessFile
 
BufferedRandomAccessFile(String, String) - Constructor for class org.apache.cassandra.io.BufferedRandomAccessFile
Open a new BufferedRandomAccessFile on the file named name in mode mode, which should be "r" for reading only, or "rw" for reading and writing.
BufferedRandomAccessFile(String, String, int) - Constructor for class org.apache.cassandra.io.BufferedRandomAccessFile
 
BuffSz_ - Static variable in class org.apache.cassandra.io.BufferedRandomAccessFile
 
bufIn_ - Variable in class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
bufOut_ - Variable in class org.apache.cassandra.db.ReadVerbHandler.ReadContext
 
byteArrayToBoolean(byte[]) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
byteArrayToInt(byte[]) - Static method in class org.apache.cassandra.net.MessagingService
 
byteArrayToInt(byte[], int) - Static method in class org.apache.cassandra.net.MessagingService
 
byteArrayToInt(byte[]) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
byteArrayToInt(byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
byteArrayToInt(byte[], int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
byteArrayToLong(byte[]) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
byteArrayToShort(byte[]) - Static method in class org.apache.cassandra.net.MessagingService
 
byteArrayToShort(byte[], int) - Static method in class org.apache.cassandra.net.MessagingService
 
byteArrayToShort(byte[]) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
bytesToHex(byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
BytesToken - Class in org.apache.cassandra.dht
 
BytesToken(byte...) - Constructor for class org.apache.cassandra.dht.BytesToken
 
BytesType - Class in org.apache.cassandra.db.marshal
 
BytesType() - Constructor for class org.apache.cassandra.db.marshal.BytesType
 

C

Cachetable<K,V> - Class in org.apache.cassandra.utils
 
Cachetable(long) - Constructor for class org.apache.cassandra.utils.Cachetable
 
Cachetable(long, ICacheExpungeHook<K, V>) - Constructor for class org.apache.cassandra.utils.Cachetable
 
calculateGrownCapacity() - Method in class org.apache.cassandra.utils.FastHash
 
callMe(K, V) - Method in interface org.apache.cassandra.utils.ICacheExpungeHook
 
capacity() - Method in class org.apache.cassandra.utils.FastHash
 
capacity() - Method in class org.apache.cassandra.utils.FastObjectHash
 
CassandraDaemon - Class in org.apache.cassandra.service
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.service.CassandraDaemon
 
CassandraServer - Class in org.apache.cassandra.service
 
CassandraServer() - Constructor for class org.apache.cassandra.service.CassandraServer
 
CFMetaData - Class in org.apache.cassandra.config
 
CFMetaData() - Constructor for class org.apache.cassandra.config.CFMetaData
 
cfName - Variable in class org.apache.cassandra.config.CFMetaData
 
cfStats(String) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
clear() - Method in class org.apache.cassandra.db.ColumnFamily
 
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.FastHash
Empties the collection.
clear() - Method in class org.apache.cassandra.utils.FastHashMap
Empties the map.
clear() - Method in class org.apache.cassandra.utils.TimedStatsDeque
 
clearSinks() - Static method in class org.apache.cassandra.net.sink.SinkManager
 
clearSnapshot() - Method in class org.apache.cassandra.db.Table
Clear all the snapshots for a given table.
clearSnapshot() - Method in class org.apache.cassandra.service.StorageService
Remove all the existing snapshots.
clearSnapshot() - Method in interface org.apache.cassandra.service.StorageServiceMBean
Remove all the existing snapshots.
clearSnapshot() - Method in class org.apache.cassandra.tools.NodeProbe
Remove all the existing snapshots.
CliClient - Class in org.apache.cassandra.cli
 
CliClient(CliSessionState, Cassandra.Client) - Constructor for class org.apache.cassandra.cli.CliClient
 
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
 
CliMain - Class in org.apache.cassandra.cli
 
CliMain() - Constructor for class org.apache.cassandra.cli.CliMain
 
CliOptions - Class in org.apache.cassandra.cli
 
CliOptions() - Constructor for class org.apache.cassandra.cli.CliOptions
 
CliSessionState - Class in org.apache.cassandra.cli
 
CliSessionState() - Constructor for class org.apache.cassandra.cli.CliSessionState
 
CliUtils - Class in org.apache.cassandra.cli
 
CliUtils() - Constructor for class org.apache.cassandra.cli.CliUtils
 
clone() - Method in class org.apache.cassandra.net.MessagingService
 
clone() - Method in class org.apache.cassandra.utils.FastHash
 
clone() - Method in class org.apache.cassandra.utils.FastHashMap
 
clone() - Method in class org.apache.cassandra.utils.FastObjectHash
 
cloneBootstrapNodes() - Method in class org.apache.cassandra.locator.TokenMetadata
 
cloneEndPointTokenMap() - Method in class org.apache.cassandra.locator.TokenMetadata
 
cloneMe() - Method in class org.apache.cassandra.db.Row
 
cloneMe() - Method in class org.apache.cassandra.locator.TokenMetadata
 
cloneMeShallow() - Method in class org.apache.cassandra.db.ColumnFamily
 
cloneMeShallow() - Method in class org.apache.cassandra.db.SuperColumn
 
cloneTokenEndPointMap() - Method in class org.apache.cassandra.locator.TokenMetadata
 
cloneTokenEndPointMapIncludingBootstrapNodes() - Method in class org.apache.cassandra.locator.TokenMetadata
 
close() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
close() - Method in interface org.apache.cassandra.db.filter.ColumnIterator
clean up any open resources
close() - Method in class org.apache.cassandra.db.filter.SimpleAbstractColumnIterator
 
close() - Method in class org.apache.cassandra.db.Scanner
 
close() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
close() - Method in class org.apache.cassandra.io.FastBufferedInputStream
Closes this input stream and releases any system resources associated with the stream.
close() - Method in class org.apache.cassandra.io.FileStruct
 
close() - Method in class org.apache.cassandra.net.TcpConnection
 
closeAndOpenReader() - Method in class org.apache.cassandra.io.SSTableWriter
Renames temporary SSTable files to valid data, index, and bloom filter files
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 class org.apache.cassandra.db.filter.NamesQueryFilter
 
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
collects columns from reducedColumns into returnCF.
collectReducedColumns(IColumnContainer, Iterator<IColumn>, int) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
Column - Class in org.apache.cassandra.db
Column is immutable, which prevents all kinds of confusion in a multithreaded environment.
Column(byte[], byte[], long) - Constructor for class org.apache.cassandra.db.Column
 
Column(byte[], byte[], long, boolean) - Constructor for class org.apache.cassandra.db.Column
 
column(byte[]) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
ColumnFamily - Class in org.apache.cassandra.db
 
ColumnFamily(String, String, AbstractType, AbstractType) - Constructor for class org.apache.cassandra.db.ColumnFamily
 
columnFamily - Variable in class org.apache.cassandra.db.RangeCommand
 
columnFamily_ - Variable in class org.apache.cassandra.db.ColumnFamilyStore
 
columnFamilyName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
columnFamilyName - Variable in class org.apache.cassandra.io.SSTable
 
columnFamilyNames() - Method in class org.apache.cassandra.db.RowMutation
 
ColumnFamilyNotDefinedException - Exception in org.apache.cassandra.db
 
ColumnFamilyNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.ColumnFamilyNotDefinedException
 
ColumnFamilySerializer - Class in org.apache.cassandra.db
 
ColumnFamilySerializer() - Constructor for class org.apache.cassandra.db.ColumnFamilySerializer
 
ColumnFamilyStore - Class in org.apache.cassandra.db
 
ColumnFamilyStoreMBean - Interface in org.apache.cassandra.db
The MBean interface for ColumnFamilyStore
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
 
ColumnIterator - Interface in org.apache.cassandra.db.filter
 
columnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
columnNames - Variable in class org.apache.cassandra.db.SliceByNamesReadCommand
 
columns - Variable in class org.apache.cassandra.db.filter.NamesQueryFilter
 
columns - Variable in class org.apache.cassandra.db.filter.SSTableNamesIterator
 
ColumnSerializer - Class in org.apache.cassandra.db
 
ColumnSerializer() - Constructor for class org.apache.cassandra.db.ColumnSerializer
 
columnType - Variable in class org.apache.cassandra.config.CFMetaData
 
commandType - Variable in class org.apache.cassandra.db.ReadCommand
 
CommitLog - Class in org.apache.cassandra.db
 
CommitLog.CommitLogContext - Class in org.apache.cassandra.db
 
CommitLog.CommitLogContext(String, long) - Constructor for class org.apache.cassandra.db.CommitLog.CommitLogContext
 
CommitLog.CommitLogFileComparator - Class in org.apache.cassandra.db
 
CommitLog.CommitLogFileComparator() - Constructor for class org.apache.cassandra.db.CommitLog.CommitLogFileComparator
 
CommitLogExecutorService - Class in org.apache.cassandra.db
 
CommitLogExecutorService() - Constructor for class org.apache.cassandra.db.CommitLogExecutorService
 
CommitLogExecutorServiceMBean - Interface in org.apache.cassandra.db
 
compact() - Method in class org.apache.cassandra.utils.FastHash
Compresses the hashtable to the minimum prime size (as defined by PrimeFinder) that will hold all of the elements currently in the table.
CompactEndPointSerializationHelper - Class in org.apache.cassandra.net
 
CompactEndPointSerializationHelper() - Constructor for class org.apache.cassandra.net.CompactEndPointSerializationHelper
 
comparator - Variable in class org.apache.cassandra.config.CFMetaData
 
compare(String, String) - Method in class org.apache.cassandra.db.CommitLog.CommitLogFileComparator
 
compare(byte[], byte[]) - Method in class org.apache.cassandra.db.marshal.BytesType
 
compare(byte[], byte[]) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
compare(byte[], byte[]) - Method in class org.apache.cassandra.db.marshal.LongType
 
compare(byte[], byte[]) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
compare(byte[], byte[]) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
compare(File, File) - Method in class org.apache.cassandra.utils.FileUtils.FileComparator
 
compareByteArrays(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
compareBytes(byte, byte) - Static method in class org.apache.cassandra.utils.FBUtilities
 
compareBytes(int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
comparePriority(Column) - Method in class org.apache.cassandra.db.Column
 
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(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(FileStruct) - Method in class org.apache.cassandra.io.FileStruct
 
compareTo(EndPoint) - Method in class org.apache.cassandra.net.EndPoint
 
compareTo(Object) - Method in class org.apache.cassandra.net.TcpConnection
 
compileQuery(String) - Static method in class org.apache.cassandra.cli.CliCompiler
 
compress(byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
COMPRESSION - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
compressToStream(byte[], ByteArrayOutputStream) - Static method in class org.apache.cassandra.utils.FBUtilities
 
computeBestK(int) - Static method in class org.apache.cassandra.utils.BloomCalculations
Given the number of buckets that can be used per element, return the optimal number of hash functions in order to minimize the false positive rate.
computeBucketsAndK(double) - Static method in class org.apache.cassandra.utils.BloomCalculations
Given a maximum tolerable false positive probability, compute a Bloom specification which will give less than the specified false positive rate, but minimize the number of buckets per element and the number of hash functions used.
computeHashCode(T) - Method in class org.apache.cassandra.utils.FastObjectHash
This is the default implementation of TObjectHashingStrategy: it delegates hashing to the Object's hashCode method.
computeNext() - Method in class org.apache.cassandra.db.filter.SSTableNamesIterator
 
computeNext() - Method in class org.apache.cassandra.io.IteratingRow
 
computeNext() - Method in class org.apache.cassandra.utils.ReducingIterator
 
connect(String, int) - Static method in class org.apache.cassandra.cli.CliMain
 
connect(SelectionKey) - Method in class org.apache.cassandra.net.SelectionKeyHandler
Method which is called when the key becomes connectable.
connect(SelectionKey) - Method in class org.apache.cassandra.net.TcpConnection
 
ConnectionStatistics - Class in org.apache.cassandra.net
 
constructEndPointToRangesMap() - Method in class org.apache.cassandra.service.StorageService
Construct a mapping from endpoint to ranges that endpoint is responsible for.
constructRangeToEndPointMap(Range[]) - Method in class org.apache.cassandra.service.StorageService
Construct the range to endpoint mapping based on the true view of the world.
constructRangeToEndPointMap(Range[], Map<Token, EndPoint>) - Method in class org.apache.cassandra.service.StorageService
Construct the range to endpoint mapping based on the view as dictated by the mapping of token to endpoints passed in.
constructStreamHeader(boolean, boolean) - Static method in class org.apache.cassandra.net.MessagingService
 
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.
contains(Object) - Method in class org.apache.cassandra.utils.FastObjectHash
Searches the set for obj
containsElement(K) - Method in class org.apache.cassandra.utils.FastHashMap.KeyView
 
containsKey(K) - Method in class org.apache.cassandra.utils.Cachetable
 
containsKey(Object) - Method in class org.apache.cassandra.utils.FastHashMap
checks for the present of key in the keys of the map.
containsKey(K) - Method in interface org.apache.cassandra.utils.ICachetable
 
containsValue(V) - Method in class org.apache.cassandra.utils.Cachetable
 
containsValue(Object) - Method in class org.apache.cassandra.utils.FastHashMap
checks for the presence of val in the values of the map.
containsValue(V) - Method in interface org.apache.cassandra.utils.ICachetable
 
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
 
convict(EndPoint) - Method in class org.apache.cassandra.gms.Gossiper
This method is part of IFailureDetectionEventListener interface.
convict(EndPoint) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
Convict the specified endpoint.
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
 
count - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
count - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
count - Variable in class org.apache.cassandra.io.FastBufferedInputStream
The index one greater than the index of the last valid byte in the buffer.
count - Variable in class org.apache.cassandra.io.FastBufferedOutputStream
The number of valid bytes in the buffer.
create(String, String) - Static method in class org.apache.cassandra.db.ColumnFamily
 
createDirectory(String) - Static method in class org.apache.cassandra.utils.FileUtils
 
createFile(String) - Static method in class org.apache.cassandra.utils.FileUtils
 
createHardLink(File, File) - Static method in class org.apache.cassandra.utils.FileUtils
Create a hard link for a given file.
createTableDirectories() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Create the table directory in each data directory
ctxBag_ - Static variable in class org.apache.cassandra.net.io.StreamContextManager
 

D

DatabaseDescriptor - Class in org.apache.cassandra.config
 
DatabaseDescriptor() - Constructor for class org.apache.cassandra.config.DatabaseDescriptor
 
DatabaseDescriptor.CommitLogSync - Enum in org.apache.cassandra.config
 
DataFileVerbHandler - Class in org.apache.cassandra.db
 
DataFileVerbHandler() - Constructor for class org.apache.cassandra.db.DataFileVerbHandler
 
dataFileVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
DataInputBuffer - Class in org.apache.cassandra.io
An implementation of the DataInputStream interface.
DataInputBuffer() - Constructor for class org.apache.cassandra.io.DataInputBuffer
Constructs a new empty buffer.
DataOutputBuffer - Class in org.apache.cassandra.io
An implementation of the DataOutputStream interface.
DataOutputBuffer() - Constructor for class org.apache.cassandra.io.DataOutputBuffer
Constructs a new empty buffer.
debug(Object) - Method in class org.apache.cassandra.utils.Log4jLogger
 
DebuggableScheduledThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This is a wrapper class for the ScheduledThreadPoolExecutor.
DebuggableScheduledThreadPoolExecutor(int, ThreadFactory) - Constructor for class org.apache.cassandra.concurrent.DebuggableScheduledThreadPoolExecutor
 
DebuggableThreadPoolExecutor - Class in org.apache.cassandra.concurrent
This is a wrapper class for the ScheduledThreadPoolExecutor.
DebuggableThreadPoolExecutor(String) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DebuggableThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactoryImpl) - Constructor for class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
DebuggableThreadPoolExecutorMBean - Interface in org.apache.cassandra.concurrent
 
debugOn(boolean) - Static method in class org.apache.cassandra.net.MessagingService
 
decompress(byte[], int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
decompress(byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
decorateKey(String) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
decorateKey(String) - Method in interface org.apache.cassandra.dht.IPartitioner
Transform key to on-disk format s.t.
decorateKey(String) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
decorateKey(String) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
DEFAULT_INITIAL_CAPACITY - Static variable in class org.apache.cassandra.utils.FastHash
the default initial capacity for the hash table.
DEFAULT_LOAD_FACTOR - Static variable in class org.apache.cassandra.utils.FastHash
the load above which rehashing occurs.
defreezeBloomFilter(RandomAccessFile) - Static method in class org.apache.cassandra.io.IndexHelper
Defreeze the bloom filter.
delete(int, long) - Method in class org.apache.cassandra.db.ColumnFamily
 
delete(ColumnFamily) - Method in class org.apache.cassandra.db.ColumnFamily
 
delete(QueryPath, long) - Method in class org.apache.cassandra.db.RowMutation
 
delete() - Method in class org.apache.cassandra.io.SSTableReader
 
delete(String) - Static method in class org.apache.cassandra.utils.FileUtils
 
delete(List<String>) - Static method in class org.apache.cassandra.utils.FileUtils
 
delete(File[]) - Static method in class org.apache.cassandra.utils.FileUtils
 
deleteApplicationState(String) - Method in class org.apache.cassandra.gms.Gossiper
 
deleteAsync(String) - Static method in class org.apache.cassandra.utils.FileUtils
 
deleteDir(File) - Static method in class org.apache.cassandra.utils.FileUtils
Deletes all files and subdirectories under "dir".
deleteWithConfirm(File) - Static method in class org.apache.cassandra.utils.FileUtils
 
deliverHints(EndPoint) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
deliverHints(EndPoint) - 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
deque - Variable in class org.apache.cassandra.utils.BoundedStatsDeque
 
deregisterAllVerbHandlers(EndPoint) - Method in interface org.apache.cassandra.net.IMessagingService
Deregister all verbhandlers corresponding to localEndPoint.
deregisterAllVerbHandlers(EndPoint) - Method in class org.apache.cassandra.net.MessagingService
 
deregisterStage(String) - Static method in class org.apache.cassandra.concurrent.StageManager
Deregister a stage from StageManager
deregisterVerbHandlers(String) - Method in interface org.apache.cassandra.net.IMessagingService
Deregister a verbhandler corresponding to the verb from the Messaging Service.
deregisterVerbHandlers(String) - Method in class org.apache.cassandra.net.MessagingService
 
describe_keyspace(String) - Method in class org.apache.cassandra.service.CassandraServer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserialize(DataInput) - Method in class org.apache.cassandra.db.ColumnSerializer
 
deserialize(DataInputStream) - Static method in class org.apache.cassandra.db.filter.QueryPath
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
deserialize(DataInputStream) - 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(RandomAccessFile) - Static method in class org.apache.cassandra.io.IndexHelper.IndexInfo
 
deserialize(DataInputStream) - Static method in class org.apache.cassandra.net.CompactEndPointSerializationHelper
 
deserialize(byte[]) - Method in class org.apache.cassandra.net.io.FastSerializer
 
deserialize(byte[]) - Method in interface org.apache.cassandra.net.io.ISerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContextSerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessageSerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusSerializer
 
deserialize(DataInputStream) - Method in class org.apache.cassandra.tools.MembershipCleaner.MembershipCleanerMessageSerializer
 
deserialize(DataInputStream) - Static method in class org.apache.cassandra.utils.BitSetSerializer
 
deserializeFromSSTableNoColumns(String, String, AbstractType, AbstractType, DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromSSTableNoColumns(ColumnFamily, DataInput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
deserializeFromStream(byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
deserializeIndex(RandomAccessFile) - Static method in class org.apache.cassandra.io.IndexHelper
Deserialize the index into a structure and return the number of bytes read.
destroy() - Method in class org.apache.cassandra.service.CassandraDaemon
hook for JSVC
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
 
diff(IColumn) - Method in class org.apache.cassandra.db.Column
 
diff(IColumn) - Method in interface org.apache.cassandra.db.IColumn
 
diff(Row) - Method in class org.apache.cassandra.db.Row
 
diff(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
digest() - Method in class org.apache.cassandra.db.ReadResponse
 
digest() - Method in class org.apache.cassandra.db.Row
 
digest(byte[]) - Method in class org.apache.cassandra.utils.SafeMessageDigest
 
digest() - Method in class org.apache.cassandra.utils.SafeMessageDigest
 
digest_ - Static variable in class org.apache.cassandra.utils.SafeMessageDigest
 
DigestMismatchException - Exception in org.apache.cassandra.service
 
DigestMismatchException(String) - Constructor for exception org.apache.cassandra.service.DigestMismatchException
 
disconnect() - Static method in class org.apache.cassandra.cli.CliMain
 
DO_REPAIR - Static variable in class org.apache.cassandra.db.ReadCommand
 
doBootstrap(EndPoint, Token) - Method in class org.apache.cassandra.service.StorageService
Starts the bootstrap operations for the specified endpoint.
doConsistencyCheck(Row, List<EndPoint>, ReadCommand) - Method in class org.apache.cassandra.service.StorageService
 
doPendingWrites() - Method in class org.apache.cassandra.net.TcpConnection
 
doProcess() - Method in class org.apache.cassandra.net.SelectorManager
 
doRead(ByteBuffer) - Method in class org.apache.cassandra.net.io.StartState
 
doRecovery() - Static method in class org.apache.cassandra.db.RecoveryManager
 
doVerb(Message) - Method in class org.apache.cassandra.db.BinaryVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.db.DataFileVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.db.ReadRepairVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.db.ReadVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.db.RowMutationVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.db.Table.BootStrapInitiateVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.dht.BootstrapMetadataVerbHandler
 
doVerb(Message) - 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) - Method in class org.apache.cassandra.service.RangeVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.service.StorageService.BootstrapInitiateDoneVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.service.StreamManager.BootstrapTerminateVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.service.TokenUpdateVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.tools.MembershipCleanerVerbHandler
 
doVerb(Message) - Method in class org.apache.cassandra.tools.TokenUpdateVerbHandler
 
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
 

E

EMPTY_CF - Static variable in class org.apache.cassandra.db.ReadCommand
 
EndPoint - Class in org.apache.cassandra.net
 
EndPoint(String, int) - Constructor for class org.apache.cassandra.net.EndPoint
 
EndPoint(int) - Constructor for class org.apache.cassandra.net.EndPoint
 
EndPointSnitch - Class in org.apache.cassandra.locator
 
EndPointSnitch() - Constructor for class org.apache.cassandra.locator.EndPointSnitch
 
EndPointState - Class in org.apache.cassandra.gms
This abstraction represents both the HeartBeatState and the ApplicationState in an EndPointState instance.
ensureCapacity(int) - Method in class org.apache.cassandra.utils.FastHash
Ensure that this hashtable has sufficient capacity to hold desiredCapacity additional elements without requiring a rehash.
entrySet() - Method in class org.apache.cassandra.utils.FastHashMap
Returns a Set view on the entries of the map.
equals(Object) - Method in class org.apache.cassandra.db.ColumnFamily
 
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.net.EndPoint
 
equals(Object) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
equals(Object) - Method in class org.apache.cassandra.net.TcpConnection
 
equals(T, T) - Method in class org.apache.cassandra.utils.FastObjectHash
This is the default implementation of TObjectHashingStrategy: it delegates equality comparisons to the first parameter's equals() method.
err - Variable in class org.apache.cassandra.cli.CliSessionState
 
error(Object) - Method in class org.apache.cassandra.utils.Log4jLogger
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Executes the given command at some time in the future.
execute(Runnable) - Method in interface org.apache.cassandra.concurrent.IStage
This method is used to execute a piece of code on this stage.
execute(Callable<Object>) - Method in interface org.apache.cassandra.concurrent.IStage
This method is used to execute a piece of code on this stage which returns a Future pointer.
execute(Callable<Object>) - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
execute(Runnable) - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
execute(Callable<Object>) - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
execute(Runnable) - Method in class org.apache.cassandra.db.CommitLogExecutorService
 
executeCLIStmt(String) - Method in class org.apache.cassandra.cli.CliClient
 
executorService_ - Variable in class org.apache.cassandra.concurrent.SingleThreadedStage
 

F

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
 
FastBufferedInputStream - Class in org.apache.cassandra.io
A BufferedInputStream adds functionality to another input stream-namely, the ability to buffer the input and to support the mark and reset methods.
FastBufferedInputStream(InputStream) - Constructor for class org.apache.cassandra.io.FastBufferedInputStream
Creates a BufferedInputStream and saves its argument, the input stream in, for later use.
FastBufferedInputStream(InputStream, int) - Constructor for class org.apache.cassandra.io.FastBufferedInputStream
Creates a BufferedInputStream with the specified buffer size, and saves its argument, the input stream in, for later use.
FastBufferedOutputStream - Class in org.apache.cassandra.io
The class implements a buffered output stream.
FastBufferedOutputStream(OutputStream) - Constructor for class org.apache.cassandra.io.FastBufferedOutputStream
Creates a new buffered output stream to write data to the specified underlying output stream.
FastBufferedOutputStream(OutputStream, int) - Constructor for class org.apache.cassandra.io.FastBufferedOutputStream
Creates a new buffered output stream to write data to the specified underlying output stream with the specified buffer size.
FastHash - Class in org.apache.cassandra.utils
Base class for hashtables that use open addressing to resolve collisions.
FastHash() - Constructor for class org.apache.cassandra.utils.FastHash
Creates a new THash instance with the default capacity and load factor.
FastHash(int) - Constructor for class org.apache.cassandra.utils.FastHash
Creates a new THash instance with a prime capacity at or near the specified capacity and with the default load factor.
FastHash(int, float) - Constructor for class org.apache.cassandra.utils.FastHash
Creates a new THash instance with a prime capacity at or near the minimum needed to hold initialCapacity elements with load factor loadFactor without triggering a rehash.
FastHashMap<K,V> - Class in org.apache.cassandra.utils
An implementation of the Map interface which uses an open addressed hash table to store its contents
FastHashMap() - Constructor for class org.apache.cassandra.utils.FastHashMap
Creates a new FastHashMap instance with the default capacity and load factor.
FastHashMap(int) - Constructor for class org.apache.cassandra.utils.FastHashMap
Creates a new FastHashMap instance with a prime capacity equal to or greater than initialCapacity and with the default load factor.
FastHashMap(int, float) - Constructor for class org.apache.cassandra.utils.FastHashMap
Creates a new FastHashMap instance with a prime capacity equal to or greater than initialCapacity and with the specified load factor.
FastHashMap(Map<K, V>) - Constructor for class org.apache.cassandra.utils.FastHashMap
Creates a new FastHashMap instance which contains the key/value pairs in map.
FastHashMap.FastHashMapIterator<T> - Class in org.apache.cassandra.utils
 
FastHashMap.KeyView - Class in org.apache.cassandra.utils
a view onto the keys of the map.
FastHashMap.KeyView() - Constructor for class org.apache.cassandra.utils.FastHashMap.KeyView
 
FastLinkedHashMap<K,V> - Class in org.apache.cassandra.utils
 
FastLinkedHashMap() - Constructor for class org.apache.cassandra.utils.FastLinkedHashMap
 
FastObjectHash<T> - Class in org.apache.cassandra.utils
An open addressed hashing implementation for Object types.
FastObjectHash() - Constructor for class org.apache.cassandra.utils.FastObjectHash
Creates a new TObjectHash instance with the default capacity and load factor.
FastObjectHash(int) - Constructor for class org.apache.cassandra.utils.FastObjectHash
Creates a new TObjectHash instance whose capacity is the next highest prime above initialCapacity + 1 unless that value is already prime.
FastObjectHash(int, float) - Constructor for class org.apache.cassandra.utils.FastObjectHash
Creates a new TObjectHash instance with a prime value at or near the specified capacity and load factor.
FastSerializer - Class in org.apache.cassandra.net.io
 
FastSerializer() - Constructor for class org.apache.cassandra.net.io.FastSerializer
 
fatal(Object) - Method in class org.apache.cassandra.utils.Log4jLogger
 
FBUtilities - Class in org.apache.cassandra.utils
 
FBUtilities() - Constructor for class org.apache.cassandra.utils.FBUtilities
 
fetch(String, String) - Method in interface org.apache.cassandra.db.IScanner
 
fetch(String, String) - Method in class org.apache.cassandra.db.Scanner
Fetch the columns associated with this key for the specified column family.
file - Variable in class org.apache.cassandra.db.CommitLog.CommitLogContext
 
FileStruct - Class in org.apache.cassandra.io
 
FileUtils - Class in org.apache.cassandra.utils
 
FileUtils() - Constructor for class org.apache.cassandra.utils.FileUtils
 
FileUtils.Deleter - Class in org.apache.cassandra.utils
 
FileUtils.Deleter(File) - Constructor for class org.apache.cassandra.utils.FileUtils.Deleter
 
FileUtils.FileComparator - Class in org.apache.cassandra.utils
 
FileUtils.FileComparator() - Constructor for class org.apache.cassandra.utils.FileUtils.FileComparator
 
Filter - Class in org.apache.cassandra.utils
 
Filter() - Constructor for class org.apache.cassandra.utils.Filter
 
filterFilename(String) - Static method in class org.apache.cassandra.io.SSTable
 
filterFilename() - Method in class org.apache.cassandra.io.SSTable
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.filter.IdentityQueryFilter
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
filterSuperColumn(SuperColumn, int) - Method in class org.apache.cassandra.db.filter.QueryFilter
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.SliceQueryFilter
 
findSuitableEndPoint(String) - Method in class org.apache.cassandra.service.StorageService
This function finds the most suitable endpoint given a key.
finish - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
finish - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
firstName - Variable in class org.apache.cassandra.io.IndexHelper.IndexInfo
 
flush(boolean) - Method in class org.apache.cassandra.db.Table
 
flush() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
Flush any bytes in the file's buffer that have not yet been written to disk.
flush() - Method in class org.apache.cassandra.io.FastBufferedOutputStream
Flushes this buffered output stream.
flushAndshutdown() - Static method in class org.apache.cassandra.net.MessagingService
 
flushMemtableOnRecovery() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
flushPeriodInMinutes - Variable in class org.apache.cassandra.config.CFMetaData
 
forceBloomFilterFailures() - Method in class org.apache.cassandra.io.SSTableReader
obviously only for testing
forceCleanup() - Method in class org.apache.cassandra.db.Table
Do a cleanup of keys that do not belong locally.
forceCompaction(List<Range>, EndPoint, List<String>) - Method in class org.apache.cassandra.db.Table
 
forceCompaction() - Method in class org.apache.cassandra.db.Table
 
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
 
forceHandoff(List<String>, String) - Method in class org.apache.cassandra.service.StorageService
 
forceHandoff(List<String>, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Stream the files in the bootstrap directory over to the node being bootstrapped.
forceTableCleanup() - Method in class org.apache.cassandra.service.StorageService
 
forceTableCleanup() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
forceTableCleanup() - Method in class org.apache.cassandra.tools.NodeProbe
Trigger a cleanup of keys on all tables.
forceTableCompaction() - Method in class org.apache.cassandra.service.StorageService
Trigger the immediate compaction of all tables.
forceTableCompaction() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
forceTableCompaction() - Method in class org.apache.cassandra.tools.NodeProbe
Trigger compaction of all tables.
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
Trigger a flush of the given CFs
FREE - Static variable in class org.apache.cassandra.utils.FastObjectHash
 
free_ - Variable in class org.apache.cassandra.utils.FastHash
the current number of free slots in the hash.
fromByteArray(byte[]) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromBytes(byte[]) - Static method in class org.apache.cassandra.net.EndPoint
 
fromString(String) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
fromString(String) - Static method in class org.apache.cassandra.net.EndPoint
 

G

get(Object) - Method in class org.apache.cassandra.concurrent.Context
 
get() - Static method in class org.apache.cassandra.concurrent.ThreadLocalContext
 
get(String) - Method in class org.apache.cassandra.db.Table
Deprecated. 
get(String, String) - Method in class org.apache.cassandra.db.Table
Deprecated. 
get(String) - Static method in class org.apache.cassandra.io.SSTableReader
 
get() - Method in interface org.apache.cassandra.net.IAsyncResult
Returns the result for the task that was submitted.
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(String, String, ColumnPath, int) - Method in class org.apache.cassandra.service.CassandraServer
 
get() - Method in class org.apache.cassandra.service.MultiQuorumResponseHandler
 
get() - Method in class org.apache.cassandra.service.QuorumResponseHandler
 
get(K) - Method in class org.apache.cassandra.utils.Cachetable
 
get(Object) - Method in class org.apache.cassandra.utils.FastHashMap
retrieves the value for key
get(K) - Method in interface org.apache.cassandra.utils.ICachetable
 
get_count(String, String, ColumnParent, int) - Method in class org.apache.cassandra.service.CassandraServer
 
get_key_range(String, String, String, String, int, int) - Method in class org.apache.cassandra.service.CassandraServer
 
get_slice(String, String, ColumnParent, SlicePredicate, int) - Method in class org.apache.cassandra.service.CassandraServer
 
get_string_list_property(String) - Method in class org.apache.cassandra.service.CassandraServer
 
get_string_property(String) - Method in class org.apache.cassandra.service.CassandraServer
 
getAction() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatus
 
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
getAllMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getAllRanges() - Method in class org.apache.cassandra.service.StorageService
Get all ranges that span the ring as per current snapshot of the token distribution.
getAllRanges(Set<Token>) - Method in class org.apache.cassandra.service.StorageService
Get all ranges that span the ring given a set of tokens.
getAllSSTablesOnDisk() - Method in class org.apache.cassandra.db.Table
 
getApplicationColumnFamilies() - Method in class org.apache.cassandra.db.Table
 
getApplicationState(String) - Method in class org.apache.cassandra.gms.EndPointState
 
getApplicationState() - Method in class org.apache.cassandra.gms.EndPointState
 
getApproximateKeyCount(List<String>) - Static method in class org.apache.cassandra.io.SSTableReader
 
getAsyncResult(String) - Static method in class org.apache.cassandra.net.MessagingService
 
getAttributeValue(Node, String) - Static method in class org.apache.cassandra.utils.XMLUtils
 
getAutoCompactionFactor() - Method in class org.apache.cassandra.utils.FastHash
 
getBits(int, int, int) - Static method in class org.apache.cassandra.net.MessagingService
 
getBits(int, int, int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
getBMTThreshold() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getBootstrapFileLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCFMetaData(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getClusterName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumn(CommonTree, int) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumn(byte[]) - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnComparator(AbstractType) - Method in class org.apache.cassandra.db.filter.QueryFilter
 
getColumnComparator(AbstractType) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getColumnComparator() - Method in class org.apache.cassandra.io.SSTableReader
 
getColumnFamilies() - Method in class org.apache.cassandra.db.Row
 
getColumnFamilies() - Method in class org.apache.cassandra.db.Table
 
getColumnFamily(CommonTree) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getColumnFamily(String, QueryPath, byte[], byte[], boolean, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamily(QueryFilter) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamily(QueryFilter, int) - 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.filter.ColumnIterator
returns the CF of the column being iterated.
getColumnFamily() - Method in class org.apache.cassandra.db.filter.SSTableNamesIterator
 
getColumnFamily(String) - Method in class org.apache.cassandra.db.Row
 
getColumnFamily() - Method in class org.apache.cassandra.io.FileStruct
 
getColumnFamilyCount() - Static method in class org.apache.cassandra.db.Table.TableMetadata
 
getColumnFamilyIDString() - Static method in class org.apache.cassandra.db.Table.TableMetadata
 
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(int) - Static method in class org.apache.cassandra.db.Table.TableMetadata
 
getColumnFamilyName() - Method in class org.apache.cassandra.io.SSTable
 
getColumnFamilyNames() - Method in class org.apache.cassandra.db.Row
 
getColumnFamilyStore(String, String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
getColumnFamilyStore(String) - Method in class org.apache.cassandra.db.Table
 
getColumnFamilyType(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnIndexSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnNames() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnSerializer() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnsMap() - Method in class org.apache.cassandra.db.ColumnFamily
 
getColumnsString(Collection<IColumn>) - Method in class org.apache.cassandra.db.marshal.AbstractType
convenience method
getColumnType(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getColumnType(String) - Static method in class org.apache.cassandra.db.ColumnFamily
 
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
 
getComparator(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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(AbstractType) - Static method in class org.apache.cassandra.io.IndexHelper
 
getComparatorFor(String, String, byte[]) - Static method in class org.apache.cassandra.db.ColumnFamily
 
getConcurrentReaders() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConcurrentWriters() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConfigFileName() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConnection(EndPoint, EndPoint) - Static method in class org.apache.cassandra.net.MessagingService
 
getConnectionInUse() - Method in class org.apache.cassandra.net.ConnectionStatistics
 
getConnectionPool(EndPoint, EndPoint) - Static method in class org.apache.cassandra.net.MessagingService
 
getConnectionPoolGrowthFactor() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getConnectionPoolInitialSize() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getConnectionPoolMaxSize() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getConnectionPoolMonitorInterval() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getConnectionPoolWaitTimeout() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getConsistencyCheck() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getConsistencyThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getControlPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getCurrentGenerationNumber(EndPoint) - 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
 
getCurrentGenerationNumber() - Method in class org.apache.cassandra.tools.NodeProbe
Return the generation value for this node.
getCurrentObjectCount() - Method in class org.apache.cassandra.db.Memtable
 
getCurrentReadContext() - Static method in class org.apache.cassandra.db.ReadVerbHandler
 
getCurrentSize() - Method in class org.apache.cassandra.db.Memtable
 
getCurrentStage() - Static method in class org.apache.cassandra.concurrent.StageManager
Returns the stage that we are currently executing on.
getCurrentThreadStackTrace() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getData() - Method in class org.apache.cassandra.io.DataOutputBuffer
Returns the current contents of the buffer.
getDataFileLocationForTable(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDataFileLocationForTable(String, long) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getDatagramChannel() - Method in class org.apache.cassandra.net.UdpConnection
 
getDecoratedKeyComparator() - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getDecoratedKeyComparator() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getDecoratedKeyComparator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getDecoratedKeyComparator() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getDefaultGCBefore() - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
getDefaultToken() - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getDefaultToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getDefaultToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getDefaultToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getDeserializationExecutor() - Static method in class org.apache.cassandra.net.MessagingService
 
getDigestLength() - Method in class org.apache.cassandra.utils.SafeMessageDigest
 
getEmptyColumnFamily() - Method in class org.apache.cassandra.io.IteratingRow
 
getEndPoint(String) - Method in class org.apache.cassandra.client.RingCache
 
getEndPoint() - Method in class org.apache.cassandra.net.TcpConnection
 
getEndPointSnitch() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getEndPointSnitch() - Method in class org.apache.cassandra.service.StorageService
 
getExpandedRangeToOldRangeMapping(Range[], Range[]) - Static method in class org.apache.cassandra.dht.LeaveJoinProtocolImpl
Here we are removing the nodes that need to leave the ring and trying to calculate what the ranges would look like w/o them.
getExpectedBytes() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
getExpectedBytes() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatus
 
getExpectedRoundTripTime() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getFile() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatus
 
getFileName() - Method in class org.apache.cassandra.io.FileStruct
 
getFilename() - Method in class org.apache.cassandra.io.SSTable
 
getFilePointer() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
getFileStruct() - Method in class org.apache.cassandra.io.SSTableReader
 
getFirstEndpoint() - Method in class org.apache.cassandra.locator.TokenMetadata
 
getFlushDataBufferSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushIndexBufferSizeInMB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushMaxThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushMinThreads() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFlushPeriod(String, String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getFrom() - Method in class org.apache.cassandra.net.Message
 
getGcGraceInSeconds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getGeneration() - Method in class org.apache.cassandra.db.SystemTable.StorageMetadata
 
getHashBuckets(String) - Method in class org.apache.cassandra.utils.Filter
 
getHashBuckets(byte[]) - Method in class org.apache.cassandra.utils.Filter
 
getHeader(Object) - Method in class org.apache.cassandra.net.Message
 
getHeaders() - Method in class org.apache.cassandra.net.Message
 
getHintedStorageEndpointMap(String) - 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.
getHintedStorageEndPoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getHintedStorageEndPointsForWrite(Token) - Method in class org.apache.cassandra.locator.RackAwareStrategy
 
getHost() - Method in class org.apache.cassandra.net.EndPoint
 
getHostAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getIndexedKeys() - Static method in class org.apache.cassandra.io.SSTableReader
Get all indexed keys in the SSTable.
getIndexedReadBufferSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getIndexFromFileName(String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
getIndexPositions() - Method in class org.apache.cassandra.io.SSTableReader
 
getInetAddress() - Method in class org.apache.cassandra.net.EndPoint
 
getInitialToken() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getInternalThreadPool() - Method in interface org.apache.cassandra.concurrent.IStage
Get the thread pool used by this stage internally.
getInternalThreadPool() - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
getInternalThreadPool() - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
getJobJarLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getJobTrackerAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getKey(CommonTree) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getKey() - Method in class org.apache.cassandra.io.FileStruct
 
getKey() - Method in class org.apache.cassandra.io.IteratingRow
 
getKeyIterator(Set<String>) - Static method in class org.apache.cassandra.db.Memtable
 
getKeyRange(String, String, int) - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getLength() - Method in class org.apache.cassandra.io.DataInputBuffer
Returns the length of the input.
getLength() - Method in class org.apache.cassandra.io.DataOutputBuffer
Returns the length of the valid data currently in the buffer.
getListenAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getListofCommitLogs() - Static method in class org.apache.cassandra.db.RecoveryManager
 
getLiveMembers() - Method in class org.apache.cassandra.gms.Gossiper
 
getLiveNodes() - Method in class org.apache.cassandra.service.StorageService
 
getLiveNodes() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getLiveNodes() - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve the list of live nodes in the cluster, where "liveness" is determined by the failure detector of the node being queried.
getLiveReadStorageEndPoints(String) - 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.
getLoadInfo() - Method in class org.apache.cassandra.service.StorageService
Get the count of primary keys from the sampler.
getLoadInfo(EndPoint) - Method in class org.apache.cassandra.service.StorageService
Get the primary count info for this endpoint.
getLoadInfo() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getLoadInfo() - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve a textual representation of the on-disk size of data stored on this node.
getLocalAddress() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getLocalControlEndPoint() - Static method in class org.apache.cassandra.service.StorageService
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.Column
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.ColumnFamily
 
getLocalDeletionTime() - Method in interface org.apache.cassandra.db.IColumn
 
getLocalDeletionTime() - Method in class org.apache.cassandra.db.SuperColumn
 
getLocalHost() - Method in class org.apache.cassandra.net.ConnectionStatistics
 
getLocalPort() - Method in class org.apache.cassandra.net.ConnectionStatistics
 
getLocalStorageEndPoint() - Static method in class org.apache.cassandra.service.StorageService
 
getLogFileLocation() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getLogger(String) - Static method in class org.apache.cassandra.utils.LogUtil
 
getLogMessage(String) - Static method in class org.apache.cassandra.utils.LogUtil
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.Column
 
getMarkedForDeleteAt() - Method in class org.apache.cassandra.db.ColumnFamily
 
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
 
getMemColumnIterator(Memtable, AbstractType) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getMemColumnIterator(Memtable, AbstractType) - Method in class org.apache.cassandra.db.filter.QueryFilter
returns an iterator that returns columns from the given memtable matching the Filter criteria in sorted order.
getMemColumnIterator(Memtable, 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.
getMemtableLifetime() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMemtableObjectCount() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getMemtableSize() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
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.
getMemtableThreshold() - Method in class org.apache.cassandra.db.BinaryMemtable
 
getMessage() - Method in class org.apache.cassandra.db.RangeCommand
 
getMessageBody() - Method in class org.apache.cassandra.net.Message
 
getMessageId() - Method in class org.apache.cassandra.net.Message
 
getMessageType() - Method in class org.apache.cassandra.net.Message
 
getMessagingInstance() - Static method in class org.apache.cassandra.net.MessagingService
 
getMessagingThreadCount() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getMinimumToken() - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getMinimumToken() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getMinimumToken() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getName() - Method in interface org.apache.cassandra.concurrent.IStage
Get the name of the associated stage.
getName() - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
getName() - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
getNamesIterator(NamesQueryFilter) - Method in class org.apache.cassandra.db.Memtable
 
getNearestPosition(String) - Method in class org.apache.cassandra.io.SSTableReader
like getPosition, but if key is not found will return the location of the first key _greater_ than the desired one, or -1 if no such key exists.
getNextAvailableEndPoint(EndPoint, List<EndPoint>, List<EndPoint>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getNextEndpoint(EndPoint) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getNextVersion() - Static method in class org.apache.cassandra.gms.VersionGenerator
 
getNodeValue(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getNodeValues(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getNumberOfPorts() - Static method in class org.apache.cassandra.net.MessagingConfig
 
getObjectCount() - Method in class org.apache.cassandra.db.Column
 
getObjectCount() - Method in interface org.apache.cassandra.db.IColumn
 
getObjectCount() - Method in class org.apache.cassandra.db.SuperColumn
 
getPartitioner() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getPartitioner() - Method in class org.apache.cassandra.io.SSTableReader
 
getPartitioner() - Static method in class org.apache.cassandra.service.StorageService
 
getPath() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
getPendingTasks() - Method in class org.apache.cassandra.concurrent.DebuggableThreadPoolExecutor
 
getPendingTasks() - Method in interface org.apache.cassandra.concurrent.IExecutorMBean
 
getPendingTasks() - Method in interface org.apache.cassandra.concurrent.IStage
This method returns the number of tasks that are pending on this stage to be executed.
getPendingTasks() - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
getPendingTasks() - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
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.CommitLogExecutorService
 
getPoolStatistics() - Static method in class org.apache.cassandra.net.MessagingService
 
getPort() - Method in class org.apache.cassandra.net.EndPoint
 
getPosition() - Method in class org.apache.cassandra.io.DataInputBuffer
 
getPosition(String) - Method in class org.apache.cassandra.io.SSTableReader
returns the position in the data file to find the given key, or -1 if the key is not present
getPrimary(String) - Method in class org.apache.cassandra.service.StorageService
This method returns the endpoint that is responsible for storing the specified key.
getPrimaryRangeForEndPoint(EndPoint) - Method in class org.apache.cassandra.service.StorageService
Get the primary range for the specified endpoint.
getProtocol() - Static method in class org.apache.cassandra.net.MessagingService
 
getProtocolHeader() - Method in class org.apache.cassandra.net.io.TcpReader
 
getQuorum() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getRangeLatency() - Method in class org.apache.cassandra.service.StorageProxy
 
getRangeLatency() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRangeOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getRangeOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getRangeToEndPointMap() - Method in class org.apache.cassandra.service.StorageService
 
getRangeToEndPointMap() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getRangeToEndpointMap() - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve a map of range to end points that describe the ring topology of a Cassandra cluster.
getReadCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getReadCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getReadExecutor() - Static method in class org.apache.cassandra.net.MessagingService
 
getReadLatency() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getReadLatency() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getReadLatency() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadLatency() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadLock() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getReadOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getReadOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getReadStorageEndPoints(Token, Map<Token, EndPoint>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getReadStorageEndPoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getReadStorageEndPoints(Token) - Method in class org.apache.cassandra.locator.RackAwareStrategy
 
getReadStorageEndPoints(Token, Map<Token, EndPoint>) - Method in class org.apache.cassandra.locator.RackAwareStrategy
 
getReadStorageEndPoints(Token) - Method in class org.apache.cassandra.locator.RackUnawareStrategy
 
getReadStorageEndPoints(Token, Map<Token, EndPoint>) - Method in class org.apache.cassandra.locator.RackUnawareStrategy
 
getReadStorageEndPoints(String) - 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.
getReduced() - Method in class org.apache.cassandra.utils.ReducingIterator
return the last object computed by reduce
getRegisteredCallback(String) - Static method in class org.apache.cassandra.net.MessagingService
 
getRemoteHost() - Method in class org.apache.cassandra.net.ConnectionStatistics
 
getRemotePort() - Method in class org.apache.cassandra.net.ConnectionStatistics
 
getReplicaPlacementStrategyClass() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReplicationFactor() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getReply(Message) - Method in class org.apache.cassandra.db.RangeReply
 
getReply(EndPoint, byte[]) - Method in class org.apache.cassandra.net.Message
 
getRequestedNodeList(String) - Method in class org.apache.cassandra.utils.XMLUtils
 
getReverseComparator() - Method in class org.apache.cassandra.db.marshal.AbstractType
 
getReverseDecoratedKeyComparator() - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getReverseDecoratedKeyComparator() - Method in interface org.apache.cassandra.dht.IPartitioner
 
getReverseDecoratedKeyComparator() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getReverseDecoratedKeyComparator() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
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(String, String) - Method in class org.apache.cassandra.db.Table
Deprecated. 
getRow(QueryFilter) - Method in class org.apache.cassandra.db.Table
 
getRowMutation(String, String, Map<String, List<ColumnOrSuperColumn>>) - Static method in class org.apache.cassandra.db.RowMutation
 
getRowMutation() - Method in class org.apache.cassandra.db.RowMutationMessage
 
getRpcTimeout() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSeeds() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSelectorManager() - Static method in class org.apache.cassandra.net.SelectorManager
Returns the SelectorManager applications should use.
getSerializerType() - Static method in class org.apache.cassandra.net.MessagingService
 
getSlicedReadBufferSizeInKB() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getSliceIterator(SliceQueryFilter, AbstractType) - 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
 
getSocketChannel() - Method in class org.apache.cassandra.net.TcpConnection
 
getSocketState(TcpReader.TcpReaderState) - Method in class org.apache.cassandra.net.io.TcpReader
 
getSortedColumns() - Method in class org.apache.cassandra.db.ColumnFamily
 
getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.NamesQueryFilter
 
getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.QueryFilter
returns an iterator that returns columns from the given SSTable matching the Filter criteria in sorted order.
getSSTableColumnIterator(SSTableReader) - Method in class org.apache.cassandra.db.filter.SliceQueryFilter
 
getSSTables() - Method in class org.apache.cassandra.db.ColumnFamilyStore
not threadsafe.
getStage(String) - Static method in class org.apache.cassandra.concurrent.StageManager
Retrieve a stage from the StageManager
getStageInternalThreadPool(String) - Static method in class org.apache.cassandra.concurrent.StageManager
Retrieve the internal thread pool associated with the specified stage name.
getStageTaskCount(String) - Static method in class org.apache.cassandra.concurrent.StageManager
This method gets the number of tasks on the stage's internal queue.
getState() - Method in class org.apache.cassandra.gms.ApplicationState
 
getStoragePort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getStream() - Method in class org.apache.cassandra.net.io.TcpReader
 
getStreamCompletionHandler(String) - Static method in class org.apache.cassandra.net.io.StreamContextManager
 
getStreamContext() - Method in class org.apache.cassandra.dht.BootstrapInitiateMessage
 
getStreamContext(String) - Static method in class org.apache.cassandra.net.io.StreamContextManager
 
getStreamStatus(String) - Static method in class org.apache.cassandra.net.io.StreamContextManager
 
getStreamStatus() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessage
 
getString(AbstractType) - Method in class org.apache.cassandra.db.Column
 
getString(AbstractType) - Method in interface org.apache.cassandra.db.IColumn
 
getString(byte[]) - Method in class org.apache.cassandra.db.marshal.AbstractType
get a string representation of the bytes suitable for log messages
getString(Collection<byte[]>) - Method in class org.apache.cassandra.db.marshal.AbstractType
convenience method
getString(byte[]) - Method in class org.apache.cassandra.db.marshal.AsciiType
 
getString(byte[]) - Method in class org.apache.cassandra.db.marshal.BytesType
 
getString(byte[]) - Method in class org.apache.cassandra.db.marshal.LexicalUUIDType
 
getString(byte[]) - Method in class org.apache.cassandra.db.marshal.LongType
 
getString(byte[]) - Method in class org.apache.cassandra.db.marshal.TimeUUIDType
 
getString(byte[]) - Method in class org.apache.cassandra.db.marshal.UTF8Type
 
getString(AbstractType) - Method in class org.apache.cassandra.db.SuperColumn
 
getSubColumn(byte[]) - Method in class org.apache.cassandra.db.Column
 
getSubColumn(byte[]) - Method in interface org.apache.cassandra.db.IColumn
 
getSubColumn(byte[]) - 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
 
getSuccessor(EndPoint) - Method in class org.apache.cassandra.service.StorageService
 
getTable(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTable() - Method in class org.apache.cassandra.db.Row
 
getTable() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
getTableMetaData(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTableName(CommonTree) - Static method in class org.apache.cassandra.cli.CliCompiler
 
getTableName() - Method in class org.apache.cassandra.io.SSTableReader
 
getTables() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTableToColumnFamilyMap() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTargetFile() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
getThriftAddress() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getThriftPort() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
getTimestamp() - Static method in class org.apache.cassandra.utils.FBUtilities
 
getTimestamp(long) - Static method in class org.apache.cassandra.utils.FBUtilities
 
getTimestamp() - Static method in class org.apache.cassandra.utils.LogUtil
 
getToken() - Method in class org.apache.cassandra.db.SystemTable.StorageMetadata
 
getToken(String) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getToken(String) - Method in interface org.apache.cassandra.dht.IPartitioner
 
getToken(String) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
getToken(String) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
getToken(EndPoint) - Method in class org.apache.cassandra.locator.TokenMetadata
 
getToken(EndPoint) - Method in class org.apache.cassandra.service.StorageService
 
getToken() - Method in class org.apache.cassandra.service.StorageService
 
getToken() - Method in interface org.apache.cassandra.service.StorageServiceMBean
 
getToken() - Method in class org.apache.cassandra.tools.NodeProbe
Fetch a string representation of the token.
getTokenFactory() - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
getTokenFactory() - Method in interface org.apache.cassandra.dht.IPartitioner
 
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
 
getTotalConnections() - Method in class org.apache.cassandra.net.ConnectionStatistics
 
getUdpSelectorManager() - Static method in class org.apache.cassandra.net.SelectorManager
 
getUnflushedMemtables(String) - Static method in class org.apache.cassandra.db.ColumnFamilyStore
 
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
 
getUnreachableNodes() - Method in class org.apache.cassandra.tools.NodeProbe
Retrieve the list of unreachable nodes in the cluster, as determined by this node's failure detector.
getUsedDiskSpace() - Static method in class org.apache.cassandra.utils.FileUtils
 
getUsedDiskSpaceForPath(String) - Static method in class org.apache.cassandra.utils.FileUtils
calculate the total space used by a file or directory
getUTF8Length(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
getVerb() - Method in class org.apache.cassandra.net.Message
 
getVerbHandler(String) - Method in interface org.apache.cassandra.net.IMessagingService
This method returns the verb handler associated with the registered verb.
getVerbHandler(String) - Method in class org.apache.cassandra.net.MessagingService
 
getVersion() - Static method in class org.apache.cassandra.net.MessagingService
 
getWriteCount() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getWriteCount() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getWriteExecutor() - Static method in class org.apache.cassandra.net.MessagingService
 
getWriteLatency() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
getWriteLatency() - Method in interface org.apache.cassandra.db.ColumnFamilyStoreMBean
 
getWriteLatency() - Method in class org.apache.cassandra.service.StorageProxy
 
getWriteLatency() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getWriteOperations() - Method in class org.apache.cassandra.service.StorageProxy
 
getWriteOperations() - Method in interface org.apache.cassandra.service.StorageProxyMBean
 
getWriteStorageEndPoints(Token) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
getWriteStorageEndPoints(Token) - Method in class org.apache.cassandra.locator.RackAwareStrategy
 
getWriteStorageEndPoints(Token) - Method in class org.apache.cassandra.locator.RackUnawareStrategy
 
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.
Gossiper - Class in org.apache.cassandra.gms
This module is responsible for Gossiping information for the local endpoint.
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

handleMessage(Message) - Method in interface org.apache.cassandra.net.sink.IMessageSink
 
hash(String, byte[]) - Method in class org.apache.cassandra.net.MessagingService
 
hash(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hash(String, byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
hash(byte[], int, int) - Method in class org.apache.cassandra.utils.MurmurHash
 
hashCode() - Method in class org.apache.cassandra.db.ColumnFamily
 
hashCode() - Method in class org.apache.cassandra.dht.Range
 
hashCode() - Method in class org.apache.cassandra.dht.Token
 
hashCode() - Method in class org.apache.cassandra.net.EndPoint
 
hashCode() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
hashCode() - Method in class org.apache.cassandra.net.TcpConnection
 
HashingSchemes - Class in org.apache.cassandra.utils
Created by IntelliJ IDEA.
HashingSchemes() - Constructor for class org.apache.cassandra.utils.HashingSchemes
 
hasNext() - Method in interface org.apache.cassandra.db.IScanner
 
hasNext() - Method in class org.apache.cassandra.db.Scanner
 
hasNext() - Method in class org.apache.cassandra.io.FileStruct
 
hasNext() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
hasNext() - Method in class org.apache.cassandra.utils.FastHashMap.FastHashMapIterator
 
Header - Class in org.apache.cassandra.net
 
HeaderTypes - Class in org.apache.cassandra.net
 
HeaderTypes() - Constructor for class org.apache.cassandra.net.HeaderTypes
 
hexToBytes(String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
HINT - Static variable in class org.apache.cassandra.db.RowMutation
 
hint_ - Static variable in class org.apache.cassandra.db.RowMutationMessage
 
HintedHandOffManager - Class in org.apache.cassandra.db
There are two ways hinted data gets delivered to the intended nodes.
HintedHandOffManager() - Constructor for class org.apache.cassandra.db.HintedHandOffManager
 
HINTS_CF - Static variable in class org.apache.cassandra.db.HintedHandOffManager
 
HISTORYFILE - Static variable in class org.apache.cassandra.cli.CliMain
 
hostName - Variable in class org.apache.cassandra.cli.CliSessionState
 

I

IAsyncCallback - Interface in org.apache.cassandra.net
 
IAsyncResult - Interface in org.apache.cassandra.net
 
ICacheExpungeHook<K,V> - Interface in org.apache.cassandra.utils
Created by IntelliJ IDEA.
ICachetable<K,V> - Interface in org.apache.cassandra.utils
 
IColumn - Interface in org.apache.cassandra.db
 
IColumnContainer - Interface in org.apache.cassandra.db
 
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
 
id_ - Variable in class org.apache.cassandra.concurrent.ThreadFactoryImpl
 
IdentityQueryFilter - Class in org.apache.cassandra.db.filter
 
IdentityQueryFilter(String, QueryPath) - Constructor for class org.apache.cassandra.db.filter.IdentityQueryFilter
Only for use in testing; will read entire CF into memory.
IEndPointSnitch - Interface in org.apache.cassandra.locator
This interface helps determine location of node in the data center relative to another node.
IEndPointStateChangePublisher - Interface in org.apache.cassandra.gms
This is implemented by the Gossiper module to publish change events to interested parties.
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 either convict/suspect 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
 
IMessageSink - Interface in org.apache.cassandra.net.sink
 
IMessagingService - Interface in org.apache.cassandra.net
An IMessagingService provides the methods for sending messages to remote endpoints.
in - Variable in class org.apache.cassandra.cli.CliSessionState
 
index(Object) - Method in class org.apache.cassandra.utils.FastObjectHash
Locates the index of obj.
INDEX_INTERVAL - Static variable in class org.apache.cassandra.io.SSTable
 
indexFilename(String) - Static method in class org.apache.cassandra.io.SSTable
 
indexFilename() - Method in class org.apache.cassandra.io.SSTable
 
indexFor(byte[], List<IndexHelper.IndexInfo>, AbstractType, boolean) - Static method in class org.apache.cassandra.io.IndexHelper
the index of the IndexInfo in which @name will be found.
IndexHelper - Class in org.apache.cassandra.io
Provides helper to serialize, deserialize and use column indexes.
IndexHelper() - Constructor for class org.apache.cassandra.io.IndexHelper
 
IndexHelper.IndexInfo - Class in org.apache.cassandra.io
 
IndexHelper.IndexInfo(byte[], byte[], long, long) - Constructor for class org.apache.cassandra.io.IndexHelper.IndexInfo
 
indexInterval() - Static method in class org.apache.cassandra.io.SSTableReader
 
indexPositions - Variable in class org.apache.cassandra.io.SSTable
 
info(Object) - Method in class org.apache.cassandra.utils.Log4jLogger
 
init() - Method in class org.apache.cassandra.net.UdpConnection
 
init(int) - Method in class org.apache.cassandra.net.UdpConnection
 
init(String[]) - Method in class org.apache.cassandra.service.CassandraDaemon
hook for JSVC
init() - Static method in class org.apache.cassandra.utils.LogUtil
 
initMetadata() - Static method in class org.apache.cassandra.db.SystemTable
 
insert(String, String, ColumnPath, byte[], long, int) - Method in class org.apache.cassandra.service.CassandraServer
 
insert(RowMutation) - Static method in class org.apache.cassandra.service.StorageProxy
Use this method to have this RowMutation applied across all replicas.
insertBlocking(RowMutation, int) - Static method in class org.apache.cassandra.service.StorageProxy
 
insertBlocking(RowMutation) - Static method in class org.apache.cassandra.service.StorageProxy
 
insertionIndex(T) - Method in class org.apache.cassandra.utils.FastObjectHash
Locates the index at which obj can be inserted.
instance() - Static method in class org.apache.cassandra.db.HintedHandOffManager
 
instance() - Static method in class org.apache.cassandra.db.RecoveryManager
 
instance(String) - Static method in class org.apache.cassandra.db.Table.TableMetadata
 
instance() - Static method in class org.apache.cassandra.gms.FailureDetector
 
instance() - Static method in class org.apache.cassandra.gms.Gossiper
 
instance() - Static method in class org.apache.cassandra.service.StorageService
 
instance(EndPoint) - Static method in class org.apache.cassandra.service.StreamManager
 
interpret(EndPoint) - Method in class org.apache.cassandra.gms.FailureDetector
 
interpret(EndPoint) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by any entity wanting to interrogate the status of an endpoint.
intToByteArray(int) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
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.
IPartitioner<T extends Token> - Interface in org.apache.cassandra.dht
 
IResponseResolver<T> - Interface in org.apache.cassandra.service
 
isAlive() - Method in class org.apache.cassandra.gms.EndPointState
 
isAlive(EndPoint) - Method in class org.apache.cassandra.gms.FailureDetector
 
isAlive(EndPoint) - Method in interface org.apache.cassandra.gms.IFailureDetector
Failure Detector's knowledge of whether a node is up or down.
isApplicationColumnFamily(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isBootstrapMode() - Method in class org.apache.cassandra.service.StorageService
 
IScanner<T> - Interface in org.apache.cassandra.db
 
isClean() - Method in class org.apache.cassandra.db.Memtable
 
isCompressed_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
isConnected() - Static method in class org.apache.cassandra.cli.CliMain
 
isConnected() - Method in class org.apache.cassandra.net.TcpConnection
 
isDataPresent(List<Message>) - Method in interface org.apache.cassandra.service.IResponseResolver
 
isDataPresent(List<Message>) - Method in class org.apache.cassandra.service.ReadResponseResolver
 
isDataPresent(List<Message>) - Method in class org.apache.cassandra.service.WriteResponseResolver
 
isDebugOn() - Static method in class org.apache.cassandra.net.MessagingService
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadCommand
 
isDigestQuery() - Method in class org.apache.cassandra.db.ReadResponse
 
isDone() - Method in interface org.apache.cassandra.net.IAsyncResult
This is used to check if the task has been completed
isDone(String) - Static method in class org.apache.cassandra.net.io.StreamContextManager
 
isEmpty() - Method in class org.apache.cassandra.db.Row
 
isEmpty() - Method in class org.apache.cassandra.db.Table.TableMetadata
 
isEmpty() - Method in class org.apache.cassandra.utils.Cachetable
 
isEmpty() - Method in class org.apache.cassandra.utils.FastHash
Tells whether this set is currently holding any elements.
isEmpty() - Method in interface org.apache.cassandra.utils.ICachetable
 
isEOF() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
isEqual(byte[], byte[]) - Static method in class org.apache.cassandra.net.MessagingService
 
isEqual(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
isEqual(T, T) - 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)
isEqualBits(byte[], byte[]) - Static method in class org.apache.cassandra.utils.FBUtilities
 
ISerializer - Interface in org.apache.cassandra.net.io
 
isExhausted() - Method in class org.apache.cassandra.io.FileStruct
 
isExists(String) - Static method in class org.apache.cassandra.utils.FileUtils
 
isFlushed() - Method in class org.apache.cassandra.db.Memtable
 
isHostLocalHost(InetAddress) - Static method in class org.apache.cassandra.utils.FBUtilities
 
isIncoming() - Method in class org.apache.cassandra.net.TcpConnection
 
isInitialized() - Static method in class org.apache.cassandra.net.sink.SinkManager
 
isInSameDataCenter(EndPoint, EndPoint) - Method in class org.apache.cassandra.locator.EndPointSnitch
 
isInSameDataCenter(EndPoint, EndPoint) - Method in interface org.apache.cassandra.locator.IEndPointSnitch
Helps determine if 2 nodes are in the same data center.
isInSameDataCenter(EndPoint) - Method in class org.apache.cassandra.service.StorageService
 
isKnownEndPoint(EndPoint) - Method in class org.apache.cassandra.locator.TokenMetadata
 
isListening_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
isLocalEndPoint(EndPoint) - Static method in class org.apache.cassandra.net.MessagingService
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.Column
 
isMarkedForDelete() - Method in class org.apache.cassandra.db.ColumnFamily
 
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
 
isOnSameRack(EndPoint, EndPoint) - Method in class org.apache.cassandra.locator.EndPointSnitch
 
isOnSameRack(EndPoint, EndPoint) - Method in interface org.apache.cassandra.locator.IEndPointSnitch
Helps determine if 2 nodes are in the same rack in the data center.
isPresent(String) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(byte[]) - Method in class org.apache.cassandra.utils.BloomFilter
 
isPresent(String) - Method in class org.apache.cassandra.utils.Filter
 
isPrimary(String) - Method in class org.apache.cassandra.service.StorageService
This method determines whether the local endpoint is the primary for the given key.
isProtocolValid(byte[]) - Static method in class org.apache.cassandra.net.MessagingService
 
isShutdown() - Method in class org.apache.cassandra.concurrent.AIOExecutorService
Returns true if this executor has been shut down.
isShutdown() - Method in interface org.apache.cassandra.concurrent.IStage
Checks if the stage has been shutdown.
isShutdown() - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
isShutdown() - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
isShutdown() - Method in class org.apache.cassandra.db.CommitLogExecutorService
 
isSnapshotBeforeCompaction() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isStreaming() - Static method in class org.apache.cassandra.net.MessagingService
 
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
 
isSuper() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
IStage - Interface in org.apache.cassandra.concurrent
An abstraction for stages as described in the SEDA paper by Matt Welsh.
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.CommitLogExecutorService
 
isThriftFramed() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
isTokenInRanges(Token, List<Range>) - Static method in class org.apache.cassandra.dht.Range
 
IStreamComplete - Interface in org.apache.cassandra.net.io
 
IteratingRow - Class in org.apache.cassandra.io
 
IteratingRow(BufferedRandomAccessFile, SSTableReader) - Constructor for class org.apache.cassandra.io.IteratingRow
 
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.FastHashMap.KeyView
 
iterator() - Method in class org.apache.cassandra.utils.ReducingIterator
 
iterator() - Method in class org.apache.cassandra.utils.TimedStatsDeque
 
IVerbHandler - Interface in org.apache.cassandra.net
IVerbHandler provides the method that all verb handlers need to implement.

K

key - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
key - Variable in class org.apache.cassandra.db.ReadCommand
 
key() - Method 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
 
KeyChecker - Class in org.apache.cassandra.tools
 
KeyChecker() - Constructor for class org.apache.cassandra.tools.KeyChecker
 
keys - Variable in class org.apache.cassandra.db.RangeReply
 
keySet() - Method in class org.apache.cassandra.utils.Cachetable
 
keySet() - Method in class org.apache.cassandra.utils.FastHashMap
returns a Set view on the keys of the map.
keySet() - Method in interface org.apache.cassandra.utils.ICachetable
 
KeyspaceNotDefinedException - Exception in org.apache.cassandra.db
 
KeyspaceNotDefinedException(String) - Constructor for exception org.apache.cassandra.db.KeyspaceNotDefinedException
 

L

LA(int) - Method in class org.apache.cassandra.cli.CliCompiler.ANTLRNoCaseStringStream
 
largestPrime - Static variable in class org.apache.cassandra.utils.PrimeFinder
The largest prime this class can generate; currently equal to Integer.MAX_VALUE.
last - Variable in class org.apache.cassandra.utils.ReducingIterator
 
lastName - Variable in class org.apache.cassandra.io.IndexHelper.IndexInfo
 
LeaveJoinProtocolImpl - Class in org.apache.cassandra.dht
This class performs the exact opposite of the operations of the BootStrapper class.
LeaveJoinProtocolImpl(EndPoint[], Token[]) - Constructor for class org.apache.cassandra.dht.LeaveJoinProtocolImpl
 
left() - Method in class org.apache.cassandra.dht.Range
Returns the left endpoint of a range.
length() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
LexicalUUIDType - Class in org.apache.cassandra.db.marshal
 
LexicalUUIDType() - Constructor for class org.apache.cassandra.db.marshal.LexicalUUIDType
 
listen(EndPoint) - Method in interface org.apache.cassandra.net.IMessagingService
Listen on the specified port.
listen(EndPoint) - Method in class org.apache.cassandra.net.MessagingService
 
listenUDP(EndPoint) - Method in interface org.apache.cassandra.net.IMessagingService
Listen on the specified port.
listenUDP(EndPoint) - Method in class org.apache.cassandra.net.MessagingService
 
loadAll(String) - Method in class org.apache.cassandra.service.StorageService
 
loadAll(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
This method will cause the local node initiate the bootstrap process for all the nodes specified in the string parameter passed in.
loadFactor_ - Variable in class org.apache.cassandra.utils.FastHash
Determines how full the internal table can become before rehashing is required.
LOCATION_CF - Static variable in class org.apache.cassandra.db.SystemTable
 
Log4jLogger - Class in org.apache.cassandra.utils
Log4j configurations may change while the application is running, potentially invalidating a logger's appender(s).
Log4jLogger(String) - Constructor for class org.apache.cassandra.utils.Log4jLogger
 
logger_ - Static variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
LogUtil - Class in org.apache.cassandra.utils
 
LogUtil() - Constructor for class org.apache.cassandra.utils.LogUtil
 
longToByteArray(long) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
LongType - Class in org.apache.cassandra.db.marshal
 
LongType() - Constructor for class org.apache.cassandra.db.marshal.LongType
 

M

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.net.CompactEndPointSerializationHelper
 
main(String[]) - Static method in class org.apache.cassandra.net.io.TcpReader
 
main(String[]) - Static method in class org.apache.cassandra.service.CassandraDaemon
 
main(String[]) - Static method in class org.apache.cassandra.tools.KeyChecker
 
main(String[]) - Static method in class org.apache.cassandra.tools.MembershipCleaner
 
main(String[]) - Static method in class org.apache.cassandra.tools.NodeProbe
 
main(String[]) - Static method in class org.apache.cassandra.tools.ThreadListBuilder
 
main(String[]) - Static method in class org.apache.cassandra.tools.TokenUpdater
 
main(String[]) - Static method in class org.apache.cassandra.utils.FastHashMap
 
main(String[]) - Static method in class org.apache.cassandra.utils.XMLUtils
 
makeBootstrapInitiateMessage(BootstrapInitiateMessage) - Static method in class org.apache.cassandra.dht.BootstrapInitiateMessage
 
makeColumnFamily() - Method in class org.apache.cassandra.io.SSTableReader
 
makeReadMessage() - Method in class org.apache.cassandra.db.ReadCommand
 
makeReadResponseMessage(ReadResponse) - Static method in class org.apache.cassandra.db.ReadResponse
 
makeRowMutationMessage() - Method in class org.apache.cassandra.db.RowMutation
 
makeRowMutationMessage(String) - Method in class org.apache.cassandra.db.RowMutation
 
makeRowMutationMessage() - Method in class org.apache.cassandra.db.RowMutationMessage
 
makeRowMutationMessage(String) - Method in class org.apache.cassandra.db.RowMutationMessage
 
makeStreamStatusMessage(StreamContextManager.StreamStatusMessage) - Static method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessage
 
makeWriteResponseMessage(Message, WriteResponse) - Static method in class org.apache.cassandra.db.WriteResponse
 
mapToString(Map<?, ?>) - Static method in class org.apache.cassandra.utils.FBUtilities
 
mark(int) - Method in class org.apache.cassandra.io.FastBufferedInputStream
See the general contract of the mark method of InputStream.
markForDeleteAt(int, long) - Method in class org.apache.cassandra.db.SuperColumn
 
marklimit - Variable in class org.apache.cassandra.io.FastBufferedInputStream
The maximum read ahead allowed after a call to the mark method before subsequent calls to the reset method fail.
markpos - Variable in class org.apache.cassandra.io.FastBufferedInputStream
The value of the pos field at the time the last mark method was called.
markSupported() - Method in class org.apache.cassandra.io.FastBufferedInputStream
Tests if this input stream supports the mark and reset methods.
MarshalException - Exception in org.apache.cassandra.db.marshal
 
MarshalException(String) - Constructor for exception org.apache.cassandra.db.marshal.MarshalException
 
MAX_NAME_LENGTH - Static variable in interface org.apache.cassandra.db.IColumn
 
maxResults - Variable in class org.apache.cassandra.db.RangeCommand
 
maxSize_ - Variable in class org.apache.cassandra.utils.FastHash
The maximum number of elements allowed without allocating more space.
mbrshipCleanerVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
MD5 - Static variable in class org.apache.cassandra.utils.HashingSchemes
 
MD5_MAX - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
mean() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
MembershipCleaner - Class in org.apache.cassandra.tools
 
MembershipCleaner() - Constructor for class org.apache.cassandra.tools.MembershipCleaner
 
MembershipCleaner.MembershipCleanerMessage - Class in org.apache.cassandra.tools
 
MembershipCleaner.MembershipCleanerMessageSerializer - Class in org.apache.cassandra.tools
 
MembershipCleaner.MembershipCleanerMessageSerializer() - Constructor for class org.apache.cassandra.tools.MembershipCleaner.MembershipCleanerMessageSerializer
 
MembershipCleanerVerbHandler - Class in org.apache.cassandra.tools
 
MembershipCleanerVerbHandler() - Constructor for class org.apache.cassandra.tools.MembershipCleanerVerbHandler
 
Memtable - Class in org.apache.cassandra.db
 
memtableKeyIterator() - Method in class org.apache.cassandra.db.ColumnFamilyStore
 
Message - Class in org.apache.cassandra.net
 
Message(String, EndPoint, String, String, byte[]) - Constructor for class org.apache.cassandra.net.Message
 
Message(Header, byte[]) - Constructor for class org.apache.cassandra.net.Message
 
Message(EndPoint, String, String, byte[]) - Constructor for class org.apache.cassandra.net.Message
 
MessageDeliveryTask - Class in org.apache.cassandra.net
 
MessageDeliveryTask(Message) - Constructor for class org.apache.cassandra.net.MessageDeliveryTask
 
MessagingConfig - Class in org.apache.cassandra.net
 
MessagingConfig() - Constructor for class org.apache.cassandra.net.MessagingConfig
 
MessagingService - Class in org.apache.cassandra.net
 
MessagingService() - Constructor for class org.apache.cassandra.net.MessagingService
 
midpoint(BytesToken, BytesToken) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
midpoint(T, T) - Method in interface org.apache.cassandra.dht.IPartitioner
Calculate a Token representing the approximate "middle" of the given range.
midpoint(StringToken, StringToken) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
midpoint(BigIntegerToken, BigIntegerToken) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
MINIMUM - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
modifications_ - Variable in class org.apache.cassandra.db.RowMutation
 
morphState() - Method in class org.apache.cassandra.net.io.ProtocolHeaderState
 
morphState() - Method in class org.apache.cassandra.net.io.ProtocolState
 
morphState() - Method in class org.apache.cassandra.net.io.StartState
 
morphState(StartState) - Method in class org.apache.cassandra.net.io.TcpReader
 
mostRecentChangeAt() - Method in class org.apache.cassandra.db.Column
 
mostRecentChangeAt() - Method in interface org.apache.cassandra.db.IColumn
 
mostRecentChangeAt() - Method in class org.apache.cassandra.db.SuperColumn
 
multiget(String, List<String>, ColumnPath, int) - Method in class org.apache.cassandra.service.CassandraServer
always returns a ColumnOrSuperColumn for each key, even if there is no data for it
multiget_slice(String, List<String>, ColumnParent, SlicePredicate, int) - Method in class org.apache.cassandra.service.CassandraServer
 
MultiQuorumResponseHandler - Class in org.apache.cassandra.service
 
MultiQuorumResponseHandler(Map<String, ReadCommand>, Map<String, EndPoint[]>) - Constructor for class org.apache.cassandra.service.MultiQuorumResponseHandler
 
MultiThreadedStage - Class in org.apache.cassandra.concurrent
This class is an implementation of the IStage interface.
MultiThreadedStage(String, int) - Constructor for class org.apache.cassandra.concurrent.MultiThreadedStage
 
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
 
mutationStage_ - Static variable in class org.apache.cassandra.service.StorageService
 
mutationVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 

N

n_columnKey - Variable in class org.apache.cassandra.config.CFMetaData
 
n_columnMap - Variable in class org.apache.cassandra.config.CFMetaData
 
n_columnTimestamp - Variable in class org.apache.cassandra.config.CFMetaData
 
n_columnValue - Variable in class org.apache.cassandra.config.CFMetaData
 
n_rowKey - Variable in class org.apache.cassandra.config.CFMetaData
 
n_superColumnKey - Variable in class org.apache.cassandra.config.CFMetaData
 
n_superColumnMap - Variable in class org.apache.cassandra.config.CFMetaData
 
name() - Method in class org.apache.cassandra.db.Column
 
name() - Method in class org.apache.cassandra.db.ColumnFamily
 
name() - Method in interface org.apache.cassandra.db.IColumn
 
name() - Method in class org.apache.cassandra.db.SuperColumn
 
NamesQueryFilter - Class in org.apache.cassandra.db.filter
 
NamesQueryFilter(String, QueryPath, SortedSet<byte[]>) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
NamesQueryFilter(String, QueryPath, byte[]) - Constructor for class org.apache.cassandra.db.filter.NamesQueryFilter
 
newTaskFor(Runnable, T) - Method in class org.apache.cassandra.db.CommitLogExecutorService
 
newTaskFor(Callable<T>) - Method in class org.apache.cassandra.db.CommitLogExecutorService
 
newThread(Runnable) - Method in class org.apache.cassandra.concurrent.ThreadFactoryImpl
 
next() - Method in interface org.apache.cassandra.db.IScanner
 
next() - Method in class org.apache.cassandra.db.Scanner
 
next() - Method in class org.apache.cassandra.io.FileStruct
do not mix with manual calls to advance().
next() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
next() - Method in class org.apache.cassandra.utils.FastHashMap.FastHashMapIterator
 
nextPrime(int) - Static method in class org.apache.cassandra.utils.PrimeFinder
Returns a prime number which is >= desiredCapacity and very close to desiredCapacity (within 11% if desiredCapacity >= 1000).
NodeProbe - Class in org.apache.cassandra.tools
JMX client operations for Cassandra.
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.
numColumnSpecifiers(CommonTree) - Static method in class org.apache.cassandra.cli.CliCompiler
 

O

offset - Variable in class org.apache.cassandra.io.IndexHelper.IndexInfo
 
onChange(EndPoint, EndPointState) - Method in interface org.apache.cassandra.gms.IEndPointStateChangeSubscriber
Use to inform interested parties about the change in the state for specified endpoint
onChange(EndPoint, EndPointState) - Method in class org.apache.cassandra.service.StorageService
Called when there is a change in application state.
onStart() - Method in class org.apache.cassandra.db.Table
 
onStreamCompletion(String, StreamContextManager.StreamContext, StreamContextManager.StreamStatus) - Method in class org.apache.cassandra.db.Table.BootstrapCompletionHandler
 
onStreamCompletion(String, StreamContextManager.StreamContext, StreamContextManager.StreamStatus) - Method in interface org.apache.cassandra.net.io.IStreamComplete
 
open(String) - Static method in class org.apache.cassandra.db.Table
 
open(String) - Static method in class org.apache.cassandra.io.SSTableReader
 
open(String, IPartitioner) - Static method in class org.apache.cassandra.io.SSTableReader
 
ophf_ - Static variable in class org.apache.cassandra.config.DatabaseDescriptor
 
OrderPreservingPartitioner - Class in org.apache.cassandra.dht
 
OrderPreservingPartitioner() - Constructor for class org.apache.cassandra.dht.OrderPreservingPartitioner
 
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.db - package org.apache.cassandra.db
 
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.dht - package org.apache.cassandra.dht
 
org.apache.cassandra.gms - package org.apache.cassandra.gms
 
org.apache.cassandra.io - package org.apache.cassandra.io
 
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.service - package org.apache.cassandra.service
 
org.apache.cassandra.tools - package org.apache.cassandra.tools
 
org.apache.cassandra.utils - package org.apache.cassandra.utils
 
out - Variable in class org.apache.cassandra.cli.CliSessionState
 

P

packIt(byte[], boolean, boolean, boolean) - Static method in class org.apache.cassandra.net.MessagingService
 
parseTableName(String) - Static method in class org.apache.cassandra.io.SSTable
 
partitioner - Variable in class org.apache.cassandra.io.SSTable
 
partitioner_ - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
path - Variable in class org.apache.cassandra.db.filter.QueryFilter
 
path - Variable in class org.apache.cassandra.io.SSTable
 
pending() - Method in class org.apache.cassandra.net.TcpConnection
 
pos - Variable in class org.apache.cassandra.io.FastBufferedInputStream
The current position in the buffer.
position - Variable in class org.apache.cassandra.db.CommitLog.CommitLogContext
 
postInsertHook(boolean) - Method in class org.apache.cassandra.utils.FastHash
After an insert, this hook is called to adjust the size/free values of the set and to perform rehashing if necessary.
preservesOrder() - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
preservesOrder() - Method in interface org.apache.cassandra.dht.IPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
preservesOrder() - Method in class org.apache.cassandra.dht.RandomPartitioner
 
pretty() - Method in class org.apache.cassandra.config.CFMetaData
 
PrimeFinder - Class in org.apache.cassandra.utils
Used to keep hash table capacities prime numbers.
PrimeFinder() - Constructor for class org.apache.cassandra.utils.PrimeFinder
 
printCluster(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
Write a list of nodes with corresponding status.
printColumnFamilyStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
 
printInfo(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
Write node information.
printRing(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
Write a textual representation of the Cassandra ring.
printThreadPoolStats(PrintStream) - Method in class org.apache.cassandra.tools.NodeProbe
Print out the size of the queues in the thread pools
processArgs(CliSessionState, String[]) - Method in class org.apache.cassandra.cli.CliOptions
 
processClientMessageSink(Message) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
processServerMessageSink(Message) - Static method in class org.apache.cassandra.net.sink.SinkManager
 
PROMPT - Static variable in class org.apache.cassandra.cli.CliMain
 
ProtocolHeader - Class in org.apache.cassandra.net
 
ProtocolHeader() - Constructor for class org.apache.cassandra.net.ProtocolHeader
 
ProtocolHeaderState - Class in org.apache.cassandra.net.io
 
ProtocolHeaderState(TcpReader) - Constructor for class org.apache.cassandra.net.io.ProtocolHeaderState
 
ProtocolState - Class in org.apache.cassandra.net.io
 
ProtocolState(TcpReader) - Constructor for class org.apache.cassandra.net.io.ProtocolState
 
put(Object, Object) - Method in class org.apache.cassandra.concurrent.Context
 
put(Context) - Static method in class org.apache.cassandra.concurrent.ThreadLocalContext
 
put(K, V) - Method in class org.apache.cassandra.utils.Cachetable
 
put(K, V, ICacheExpungeHook<K, V>) - Method in class org.apache.cassandra.utils.Cachetable
 
put(K, V) - Method in class org.apache.cassandra.utils.FastHashMap
Inserts a key/value pair into the map.
put(K, V) - Method in interface org.apache.cassandra.utils.ICachetable
 
put(K, V, ICacheExpungeHook<K, V>) - Method in interface org.apache.cassandra.utils.ICachetable
 
putAll(Map<? extends K, ? extends V>) - Method in class org.apache.cassandra.utils.FastHashMap
copies the key/value mappings in map into this map.
putColumn(IColumn) - Method in class org.apache.cassandra.db.SuperColumn
 
putSocketState(TcpReader.TcpReaderState, StartState) - Method in class org.apache.cassandra.net.io.TcpReader
 

Q

QueryFilter - Class in org.apache.cassandra.db.filter
 
QueryFilter(String, QueryPath) - Constructor for class org.apache.cassandra.db.filter.QueryFilter
 
QueryPath - Class in org.apache.cassandra.db.filter
 
QueryPath(String, byte[], byte[]) - Constructor for class org.apache.cassandra.db.filter.QueryPath
 
QueryPath(ColumnParent) - Constructor for class org.apache.cassandra.db.filter.QueryPath
 
QueryPath(String, byte[]) - 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
 
QuorumResponseHandler<T> - Class in org.apache.cassandra.service
 
QuorumResponseHandler(int, IResponseResolver<T>) - Constructor for class org.apache.cassandra.service.QuorumResponseHandler
 

R

RackAwareStrategy - Class in org.apache.cassandra.locator
 
RackAwareStrategy(TokenMetadata, IPartitioner, int, int) - Constructor for class org.apache.cassandra.locator.RackAwareStrategy
 
RackUnawareStrategy - Class in org.apache.cassandra.locator
This class returns the nodes responsible for a given key but does not respect rack awareness.
RackUnawareStrategy(TokenMetadata, IPartitioner, int, int) - Constructor for class org.apache.cassandra.locator.RackUnawareStrategy
 
random_ - Static variable in class org.apache.cassandra.config.DatabaseDescriptor
 
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 - 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
 
RangeCommand - Class in org.apache.cassandra.db
 
RangeCommand(String, String, String, String, int) - Constructor for class org.apache.cassandra.db.RangeCommand
 
rangeCompletedLocally - Variable in class org.apache.cassandra.db.RangeReply
 
RangeReply - Class in org.apache.cassandra.db
 
RangeReply(List<String>, boolean) - Constructor for class org.apache.cassandra.db.RangeReply
 
RangeVerbHandler - Class in org.apache.cassandra.service
 
RangeVerbHandler() - Constructor for class org.apache.cassandra.service.RangeVerbHandler
 
rangeVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
read(Message) - Static method in class org.apache.cassandra.db.RangeCommand
 
read(byte[]) - Static method in class org.apache.cassandra.db.RangeReply
 
read() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
read(byte[]) - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
read(byte[], int, int) - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
read() - Method in class org.apache.cassandra.io.FastBufferedInputStream
See the general contract of the read method of InputStream.
read(byte[], int, int) - Method in class org.apache.cassandra.io.FastBufferedInputStream
Reads bytes from this byte-input stream into the specified byte array, starting at the given offset.
read() - Method in class org.apache.cassandra.net.io.ProtocolHeaderState
 
read() - Method in class org.apache.cassandra.net.io.ProtocolState
 
read() - Method in class org.apache.cassandra.net.io.StartState
 
read() - Method in class org.apache.cassandra.net.io.TcpReader
 
read(SelectionKey) - Method in class org.apache.cassandra.net.SelectionKeyHandler
Method which is called when the key becomes readable.
read(SelectionKey) - Method in class org.apache.cassandra.net.TcpConnection
 
read(SelectionKey) - Method in class org.apache.cassandra.net.UdpConnection
 
readByteArray(DataInput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
readColumnFamily(List<ReadCommand>, int) - Method in class org.apache.cassandra.service.CassandraServer
 
ReadCommand - Class in org.apache.cassandra.db
 
ReadCommand(String, String, QueryPath, byte) - Constructor for class org.apache.cassandra.db.ReadCommand
 
readName(DataInput) - Static method in class org.apache.cassandra.db.ColumnSerializer
 
ReadNotCompleteException - Exception in org.apache.cassandra.net.io
Created by IntelliJ IDEA.
readProtocol(List<ReadCommand>, int) - 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.
ReadRepairVerbHandler - Class in org.apache.cassandra.db
 
ReadRepairVerbHandler() - Constructor for class org.apache.cassandra.db.ReadRepairVerbHandler
 
readRepairVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
ReadResponse - Class in org.apache.cassandra.db
 
ReadResponse(byte[]) - Constructor for class org.apache.cassandra.db.ReadResponse
 
ReadResponse(Row) - Constructor for class org.apache.cassandra.db.ReadResponse
 
ReadResponseResolver - Class in org.apache.cassandra.service
This class is used by all read functions and is called by the Quorum when at least a few of the servers (few is specified in Quorum) have sent the response .
ReadResponseResolver() - Constructor for class org.apache.cassandra.service.ReadResponseResolver
 
readStage_ - Static variable in class org.apache.cassandra.service.StorageService
 
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
 
readVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
receive(Message) - Static method in class org.apache.cassandra.net.MessagingService
 
RecoveryManager - Class in org.apache.cassandra.db
 
RecoveryManager() - Constructor for class org.apache.cassandra.db.RecoveryManager
 
reduce(T) - Method in class org.apache.cassandra.utils.ReducingIterator
combine this object with the previous ones.
ReducingIterator<T> - Class in org.apache.cassandra.utils
reduces equal values from the source iterator to a single (optionally transformed) instance.
ReducingIterator(Iterator<T>) - Constructor for class org.apache.cassandra.utils.ReducingIterator
 
reenableAutoCompaction(boolean) - Method in class org.apache.cassandra.utils.FastHash
Re-enable auto-compaction after it was disabled via FastHash.tempDisableAutoCompaction().
refreshEndPointMap() - Method in class org.apache.cassandra.client.RingCache
 
register(IEndPointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
 
register(IEndPointStateChangeSubscriber) - Method in interface org.apache.cassandra.gms.IEndPointStateChangePublisher
Register for interesting state changes.
register(SelectableChannel, SelectionKeyHandler, int) - Method in class org.apache.cassandra.net.SelectorManager
Registers a new channel with the selector, and attaches the given SelectionKeyHandler as the handler for the newly created key.
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.
registerStage(String, IStage) - Static method in class org.apache.cassandra.concurrent.StageManager
Register a stage with the StageManager
registerStreamCompletionHandler(String, IStreamComplete) - Static method in class org.apache.cassandra.net.io.StreamContextManager
 
registerVerbHandlers(String, IVerbHandler) - Method in interface org.apache.cassandra.net.IMessagingService
Register a verb and the corresponding verb handler with the Messaging Service.
registerVerbHandlers(String, IVerbHandler) - Method in class org.apache.cassandra.net.MessagingService
 
rehash(int) - Method in class org.apache.cassandra.utils.FastHash
Rehashes the set.
rehash(int) - Method in class org.apache.cassandra.utils.FastHashMap
rehashes the map to the new capacity.
relocate(String[]) - Method in class org.apache.cassandra.service.StorageService
 
remove(Object) - Method in class org.apache.cassandra.concurrent.Context
 
remove(byte[]) - Method in class org.apache.cassandra.db.ColumnFamily
 
remove() - Method in class org.apache.cassandra.db.filter.AbstractColumnIterator
 
remove(byte[]) - Method in class org.apache.cassandra.db.SuperColumn
 
remove() - Method in class org.apache.cassandra.io.FileStruct
 
remove(EndPoint) - Method in class org.apache.cassandra.locator.TokenMetadata
Remove the entries in the two maps.
remove(String, String, ColumnPath, long, int) - Method in class org.apache.cassandra.service.CassandraServer
 
remove(K) - Method in class org.apache.cassandra.utils.Cachetable
 
remove() - Method in class org.apache.cassandra.utils.DestructivePQIterator
 
remove() - Method in class org.apache.cassandra.utils.FastHashMap.FastHashMapIterator
 
remove(Object) - Method in class org.apache.cassandra.utils.FastHashMap
Deletes a key/value pair from the map.
remove(K) - Method in interface org.apache.cassandra.utils.ICachetable
 
removeAsyncResult(String) - Static method in class org.apache.cassandra.net.MessagingService
 
removeAt(int) - Method in class org.apache.cassandra.utils.FastHash
Delete the record at index.
removeAt(int) - Method in class org.apache.cassandra.utils.FastHashMap
removes the mapping at index from the map.
removeAt(int) - Method in class org.apache.cassandra.utils.FastObjectHash
 
removeBootstrapSource(EndPoint) - Method in class org.apache.cassandra.service.StorageService
 
REMOVED - Static variable in class org.apache.cassandra.utils.FastObjectHash
 
removeElement(K) - Method in class org.apache.cassandra.utils.FastHashMap.KeyView
 
removeFromMembership(EndPoint) - Method in class org.apache.cassandra.gms.Gossiper
This method is used to forcibly remove a node from the membership set.
removeHeader(Object) - Method in class org.apache.cassandra.net.Message
 
removeRegisteredCallback(String) - Static method in class org.apache.cassandra.net.MessagingService
 
removeStreamCompletionHandler(String) - Static method in class org.apache.cassandra.net.io.StreamContextManager
 
removeTokenState(EndPoint) - Method in class org.apache.cassandra.service.StorageService
 
renameAndOpen(String) - Static method in class org.apache.cassandra.io.SSTableWriter
 
repair(Row) - Method in class org.apache.cassandra.db.Row
 
replicas_ - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
report(EndPoint) - Method in class org.apache.cassandra.gms.FailureDetector
 
report(EndPoint) - Method in interface org.apache.cassandra.gms.IFailureDetector
This method is invoked by the receiver of the heartbeat.
reset(byte[], int) - Method in class org.apache.cassandra.io.DataInputBuffer
Resets the data that the buffer reads.
reset(byte[], int, int) - Method in class org.apache.cassandra.io.DataInputBuffer
Resets the data that the buffer reads.
reset() - Method in class org.apache.cassandra.io.DataOutputBuffer
Resets the buffer to empty.
reset() - Method in class org.apache.cassandra.io.FastBufferedInputStream
See the general contract of the reset method of InputStream.
resetState() - Method in class org.apache.cassandra.net.io.TcpReader
 
resolve(List<Message>) - Method in interface org.apache.cassandra.service.IResponseResolver
 
resolve(List<Message>) - Method in class org.apache.cassandra.service.ReadResponseResolver
 
resolve(List<Message>) - Method in class org.apache.cassandra.service.WriteResponseResolver
 
response(Message) - Method in interface org.apache.cassandra.net.IAsyncCallback
 
response(Message) - Method in class org.apache.cassandra.service.MultiQuorumResponseHandler
The handler of the response message that has been sent by one of the replicas for one of the keys.
response(Message) - Method in class org.apache.cassandra.service.QuorumResponseHandler
 
responseStage_ - Static variable in class org.apache.cassandra.net.MessagingService
 
responseVerbHandler_ - Static variable in class org.apache.cassandra.net.MessagingService
 
result(Message) - Method in interface org.apache.cassandra.net.IAsyncResult
Store the result obtained for the submitted task.
retrofitPorts(List<EndPoint>) - Method in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
reversed - Variable in class org.apache.cassandra.db.filter.SliceQueryFilter
 
reversed - Variable in class org.apache.cassandra.db.SliceFromReadCommand
 
revive(EndPoint) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
right() - Method in class org.apache.cassandra.dht.Range
Returns the right endpoint of a range.
RingCache - Class in org.apache.cassandra.client
A class for caching the ring map at the client.
RingCache() - Constructor for class org.apache.cassandra.client.RingCache
 
row() - Method in class org.apache.cassandra.db.ReadResponse
 
Row - Class in org.apache.cassandra.db
 
Row(String, String) - Constructor for class org.apache.cassandra.db.Row
 
row_ - Variable in class org.apache.cassandra.db.RowMutationVerbHandler.RowMutationContext
 
RowMutation - Class in org.apache.cassandra.db
 
RowMutation(String, String) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, Row) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutation(String, String, Map<String, ColumnFamily>) - Constructor for class org.apache.cassandra.db.RowMutation
 
RowMutationMessage - Class in org.apache.cassandra.db
 
RowMutationMessage(RowMutation) - Constructor for class org.apache.cassandra.db.RowMutationMessage
 
RowMutationVerbHandler - Class in org.apache.cassandra.db
 
RowMutationVerbHandler() - Constructor for class org.apache.cassandra.db.RowMutationVerbHandler
 
RowMutationVerbHandler.RowMutationContext - Class in org.apache.cassandra.db
 
RowMutationVerbHandler.RowMutationContext() - Constructor for class org.apache.cassandra.db.RowMutationVerbHandler.RowMutationContext
 
run() - Method in class org.apache.cassandra.dht.BootStrapper
 
run() - Method in class org.apache.cassandra.dht.LeaveJoinProtocolImpl
 
run() - Method in class org.apache.cassandra.net.MessageDeliveryTask
 
run() - Method in class org.apache.cassandra.net.SelectorManager
This method starts the socket manager listening for events.
run() - Method in class org.apache.cassandra.utils.FileUtils.Deleter
 

S

SafeMessageDigest - Class in org.apache.cassandra.utils
 
SafeMessageDigest(MessageDigest) - Constructor for class org.apache.cassandra.utils.SafeMessageDigest
 
Scanner - Class in org.apache.cassandra.db
This class is used to loop through a retrieved column family to get all columns in Iterator style.
Scanner(String) - Constructor for class org.apache.cassandra.db.Scanner
 
schedule(Runnable, long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.IStage
This method is used to submit tasks to this stage that execute periodically.
schedule(Runnable, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
schedule(Runnable, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.IStage
This method is used to submit tasks to this stage that execute periodically.
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in interface org.apache.cassandra.concurrent.IStage
This method is used to submit tasks to this stage that execute periodically.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
seek(long) - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
seekTo(String) - Method in class org.apache.cassandra.io.FileStruct
 
SelectionKeyHandler - Class in org.apache.cassandra.net
 
SelectionKeyHandler() - Constructor for class org.apache.cassandra.net.SelectionKeyHandler
 
selector - Variable in class org.apache.cassandra.net.SelectorManager
 
SelectorManager - Class in org.apache.cassandra.net
 
sendOneWay(Message, EndPoint) - Method in interface org.apache.cassandra.net.IMessagingService
Send a message to a given endpoint.
sendOneWay(Message, EndPoint) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message, EndPoint) - Method in interface org.apache.cassandra.net.IMessagingService
Send a message to a given endpoint.
sendRR(Message, EndPoint[], IAsyncCallback) - Method in interface org.apache.cassandra.net.IMessagingService
Send a message to the given set of endpoints and informs the MessagingService to wait for at least howManyResults responses to determine success of failure.
sendRR(Message, EndPoint, IAsyncCallback) - Method in interface org.apache.cassandra.net.IMessagingService
Send a message to a given endpoint.
sendRR(Message[], EndPoint[], IAsyncCallback) - Method in interface org.apache.cassandra.net.IMessagingService
Send a message to a given endpoint.
sendRR(Message[][], EndPoint[][], IAsyncCallback) - Method in interface org.apache.cassandra.net.IMessagingService
Send a message to a given endpoint.
sendRR(Message, EndPoint[], IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message, EndPoint, IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message[], EndPoint[], IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message[][], EndPoint[][], IAsyncCallback) - Method in class org.apache.cassandra.net.MessagingService
 
sendRR(Message, EndPoint) - Method in class org.apache.cassandra.net.MessagingService
 
sendUdpOneWay(Message, EndPoint) - Method in interface org.apache.cassandra.net.IMessagingService
Send a message to a given endpoint.
sendUdpOneWay(Message, EndPoint) - Method in class org.apache.cassandra.net.MessagingService
 
sentinelLocalEndPoint_ - Static variable in class org.apache.cassandra.net.EndPoint
 
sentinelPort_ - Static variable in class org.apache.cassandra.net.EndPoint
 
serialize(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serialize(ColumnFamily, 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(DataOutputStream) - Method in class org.apache.cassandra.db.filter.QueryPath
 
serialize(WriteResponse, DataOutputStream) - Method in class org.apache.cassandra.db.WriteResponse.WriteResponseSerializer
 
serialize(Token, DataOutputStream) - Method in class org.apache.cassandra.dht.Token.TokenSerializer
 
serialize(T, DataOutputStream) - 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(DataOutput) - Method in class org.apache.cassandra.io.IndexHelper.IndexInfo
 
serialize(EndPoint, DataOutputStream) - Static method in class org.apache.cassandra.net.CompactEndPointSerializationHelper
 
serialize(Message) - Method in class org.apache.cassandra.net.io.FastSerializer
 
serialize(Message) - Method in interface org.apache.cassandra.net.io.ISerializer
 
serialize(StreamContextManager.StreamContext, DataOutputStream) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContextSerializer
 
serialize(StreamContextManager.StreamStatusMessage, DataOutputStream) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessageSerializer
 
serialize(StreamContextManager.StreamStatus, DataOutputStream) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusSerializer
 
serialize(MembershipCleaner.MembershipCleanerMessage, DataOutputStream) - Method in class org.apache.cassandra.tools.MembershipCleaner.MembershipCleanerMessageSerializer
 
serialize(BitSet, DataOutputStream) - Static method in class org.apache.cassandra.utils.BitSetSerializer
 
serializedSize() - Method in class org.apache.cassandra.db.Column
 
serializedSize() - Method in class org.apache.cassandra.db.ColumnFamily
 
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() - Method in class org.apache.cassandra.io.IndexHelper.IndexInfo
 
serializeForSSTable(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
serializer() - Static method in class org.apache.cassandra.db.ColumnFamily
 
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.WriteResponse
 
serializer() - Static method in class org.apache.cassandra.dht.BootstrapInitiateMessage
 
serializer() - Static method in class org.apache.cassandra.dht.Range
 
serializer() - Static method in class org.apache.cassandra.dht.Token
 
serializer() - Static method in class org.apache.cassandra.gms.ApplicationState
 
serializer() - Static method in class org.apache.cassandra.gms.EndPointState
 
serializer() - Static method in class org.apache.cassandra.gms.GossipDigest
 
serializer() - Static method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
serializer() - Static method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatus
 
serializer() - Static method in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessage
 
serializer() - Static method in class org.apache.cassandra.net.Message
 
SERIALIZER - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
serializer() - Static method in class org.apache.cassandra.utils.BloomFilter
 
SerializerAttribute - Annotation Type in org.apache.cassandra.net.io
 
SerializerType - Enum in org.apache.cassandra.net.io
 
serializerType(String) - Static method in class org.apache.cassandra.net.MessagingService
 
serializerType_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
serializeToStream(Object) - Static method in class org.apache.cassandra.utils.FBUtilities
 
serializeWithIndexes(ColumnFamily, DataOutput) - Method in class org.apache.cassandra.db.ColumnFamilySerializer
 
set_ - Variable in class org.apache.cassandra.utils.FastObjectHash
the set of Objects
setAutoCompactionFactor(float) - Method in class org.apache.cassandra.utils.FastHash
The auto-compaction factor controls whether and when a table performs a FastHash.compact() automatically after a certain number of remove operations.
setBootstrapFileLocation(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setContextData(Object) - Method in class org.apache.cassandra.net.io.ProtocolHeaderState
 
setContextData(Object) - Method in class org.apache.cassandra.net.io.ProtocolState
 
setContextData(Object) - Method in class org.apache.cassandra.net.io.StartState
 
setCurrentReadContext(ReadVerbHandler.ReadContext) - Static method in class org.apache.cassandra.db.ReadVerbHandler
 
setDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadCommand
 
setExpectedRoundTripTime(int) - Static method in class org.apache.cassandra.net.MessagingConfig
 
setIsDigestQuery(boolean) - Method in class org.apache.cassandra.db.ReadResponse
 
setLocalEp(EndPoint) - Method in class org.apache.cassandra.net.TcpConnection
 
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
setLogFileLocation(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setLogLevel(String, String) - Static method in class org.apache.cassandra.utils.LogUtil
 
setMessageBody(byte[]) - Method in class org.apache.cassandra.net.Message
 
setMessageType(String) - Method in class org.apache.cassandra.net.Message
 
setMessageVerb(String) - Method in class org.apache.cassandra.net.Message
 
setMessagingThreadCount(int) - Static method in class org.apache.cassandra.net.MessagingConfig
 
setNumberOfPorts(int) - Static method in class org.apache.cassandra.net.MessagingConfig
 
setPort(int) - Method in class org.apache.cassandra.net.EndPoint
 
setSegmentSize(int) - Static method in class org.apache.cassandra.db.CommitLog
 
setStreamingMode(boolean) - Static method in class org.apache.cassandra.net.MessagingService
 
setTable(String) - Method in class org.apache.cassandra.db.Row
 
setTables(String) - Static method in class org.apache.cassandra.config.DatabaseDescriptor
 
setTargetFile(String) - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
setToken(Token) - Method in class org.apache.cassandra.db.SystemTable.StorageMetadata
 
setUp(int) - Method in class org.apache.cassandra.utils.FastHash
initializes the hashtable to a prime capacity which is at least initialCapacity + 1.
setUp(int) - Method in class org.apache.cassandra.utils.FastHashMap
initialize the value array of the map.
setUp(int) - Method in class org.apache.cassandra.utils.FastObjectHash
initializes the Object set of this hash table.
setVersion(int) - Static method in class org.apache.cassandra.net.MessagingService
 
SHA1 - Static variable in class org.apache.cassandra.utils.HashingSchemes
 
SHA_1 - Static variable in class org.apache.cassandra.utils.HashingSchemes
 
shortToByteArray(short) - Static method in class org.apache.cassandra.utils.BasicUtilities
 
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 interface org.apache.cassandra.concurrent.IStage
Shutdown the stage.
shutdown() - Method in class org.apache.cassandra.concurrent.MultiThreadedStage
 
shutdown() - Method in class org.apache.cassandra.concurrent.SingleThreadedStage
 
shutdown() - Static method in class org.apache.cassandra.concurrent.StageManager
This method shuts down all registered stages.
shutdown() - Method in class org.apache.cassandra.db.CommitLogExecutorService
 
shutdown() - Static method in class org.apache.cassandra.net.MessagingService
 
shutdown() - Method in class org.apache.cassandra.utils.Cachetable
 
shutdown() - Static method in class org.apache.cassandra.utils.FileUtils
 
shutdown() - Method in interface org.apache.cassandra.utils.ICachetable
 
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.db.CommitLogExecutorService
 
SimpleAbstractColumnIterator - Class in org.apache.cassandra.db.filter
 
SimpleAbstractColumnIterator() - Constructor for class org.apache.cassandra.db.filter.SimpleAbstractColumnIterator
 
SingleThreadedStage - Class in org.apache.cassandra.concurrent
This class is an implementation of the IStage interface.
SingleThreadedStage(String) - Constructor for class org.apache.cassandra.concurrent.SingleThreadedStage
 
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.db.Column
 
size() - Method in interface org.apache.cassandra.db.IColumn
 
size() - Method in class org.apache.cassandra.db.SuperColumn
 
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.Cachetable
 
size() - Method in class org.apache.cassandra.utils.FastHash
Returns the number of distinct elements in this collection.
size() - Method in interface org.apache.cassandra.utils.ICachetable
 
size() - Method in class org.apache.cassandra.utils.TimedStatsDeque
 
size_ - Variable in class org.apache.cassandra.utils.FastHash
the current number of occupied slots in the hash.
skip(long) - Method in class org.apache.cassandra.io.FastBufferedInputStream
See the general contract of the skip method of InputStream.
skipBloomFilter(DataInput) - Static method in class org.apache.cassandra.io.IndexHelper
Skip the bloom filter and return the bytes read.
skipBloomFilterAndIndex(DataInput) - Static method in class org.apache.cassandra.io.IndexHelper
Skip the bloom filter and the index and return the bytes read.
skipRemaining() - Method in class org.apache.cassandra.io.IteratingRow
 
SliceByNamesReadCommand - Class in org.apache.cassandra.db
 
SliceByNamesReadCommand(String, String, ColumnParent, Collection<byte[]>) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
 
SliceByNamesReadCommand(String, String, QueryPath, Collection<byte[]>) - Constructor for class org.apache.cassandra.db.SliceByNamesReadCommand
 
SliceFromReadCommand - Class in org.apache.cassandra.db
 
SliceFromReadCommand(String, String, ColumnParent, byte[], byte[], boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceFromReadCommand(String, String, QueryPath, byte[], byte[], boolean, int) - Constructor for class org.apache.cassandra.db.SliceFromReadCommand
 
SliceQueryFilter - Class in org.apache.cassandra.db.filter
 
SliceQueryFilter(String, QueryPath, byte[], byte[], 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.
source - Variable in class org.apache.cassandra.utils.ReducingIterator
 
SSTable - Class in org.apache.cassandra.io
This class is built on top of the SequenceFile.
SSTable(String, IPartitioner) - Constructor for class org.apache.cassandra.io.SSTable
 
SSTableNamesIterator - Class in org.apache.cassandra.db.filter
 
SSTableNamesIterator(SSTableReader, String, SortedSet<byte[]>) - Constructor for class org.apache.cassandra.db.filter.SSTableNamesIterator
 
SSTableReader - Class in org.apache.cassandra.io
 
SSTableWriter - Class in org.apache.cassandra.io
 
SSTableWriter(String, int, IPartitioner) - Constructor for class org.apache.cassandra.io.SSTableWriter
 
stackTrace(Throwable) - Static method in class org.apache.cassandra.utils.FBUtilities
 
stackTrace(Throwable) - Static method in class org.apache.cassandra.utils.LogUtil
 
StageManager - Class in org.apache.cassandra.concurrent
This class manages all stages that exist within a process.
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(EndPoint, int) - Method in class org.apache.cassandra.gms.Gossiper
 
start() - Method in class org.apache.cassandra.service.CassandraDaemon
hook for JSVC
start() - Method in class org.apache.cassandra.service.CassandraServer
 
start() - Method in class org.apache.cassandra.service.StorageService
 
StartState - Class in org.apache.cassandra.net.io
 
StartState(TcpReader) - Constructor for class org.apache.cassandra.net.io.StartState
 
startWith - Variable in class org.apache.cassandra.db.RangeCommand
 
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.CassandraDaemon
hook for JSVC
stopAt - Variable in class org.apache.cassandra.db.RangeCommand
 
storagePort_ - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
StorageProxy - Class in org.apache.cassandra.service
 
StorageProxyMBean - Interface in org.apache.cassandra.service
 
storageService - Variable in class org.apache.cassandra.service.CassandraServer
 
StorageService - Class in org.apache.cassandra.service
 
StorageService(boolean) - Constructor for class org.apache.cassandra.service.StorageService
 
StorageService.BootstrapInitiateDoneVerbHandler - Class in org.apache.cassandra.service
 
StorageService.BootstrapInitiateDoneVerbHandler() - Constructor for class org.apache.cassandra.service.StorageService.BootstrapInitiateDoneVerbHandler
 
StorageServiceMBean - Interface in org.apache.cassandra.service
 
storeMetadata() - Static method in class org.apache.cassandra.config.DatabaseDescriptor
Create the metadata tables.
stream(String, long, long, EndPoint, EndPoint) - Method in interface org.apache.cassandra.net.IMessagingService
Stream a file from source to destination.
stream(String, long, long, EndPoint, EndPoint) - Method in class org.apache.cassandra.net.MessagingService
 
stream(File, long, long) - Method in class org.apache.cassandra.net.TcpConnection
 
stream_ - Variable in class org.apache.cassandra.net.io.StartState
 
StreamContextManager - Class in org.apache.cassandra.net.io
 
StreamContextManager() - Constructor for class org.apache.cassandra.net.io.StreamContextManager
 
StreamContextManager.StreamCompletionAction - Enum in org.apache.cassandra.net.io
 
StreamContextManager.StreamContext - Class in org.apache.cassandra.net.io
 
StreamContextManager.StreamContext(String, long, String) - Constructor for class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
StreamContextManager.StreamContextSerializer - Class in org.apache.cassandra.net.io
 
StreamContextManager.StreamContextSerializer() - Constructor for class org.apache.cassandra.net.io.StreamContextManager.StreamContextSerializer
 
StreamContextManager.StreamStatus - Class in org.apache.cassandra.net.io
 
StreamContextManager.StreamStatus(String, long) - Constructor for class org.apache.cassandra.net.io.StreamContextManager.StreamStatus
 
StreamContextManager.StreamStatusMessage - Class in org.apache.cassandra.net.io
 
StreamContextManager.StreamStatusMessage(StreamContextManager.StreamStatus) - Constructor for class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessage
 
StreamContextManager.StreamStatusMessageSerializer - Class in org.apache.cassandra.net.io
 
StreamContextManager.StreamStatusMessageSerializer() - Constructor for class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessageSerializer
 
StreamContextManager.StreamStatusSerializer - Class in org.apache.cassandra.net.io
 
StreamContextManager.StreamStatusSerializer() - Constructor for class org.apache.cassandra.net.io.StreamContextManager.StreamStatusSerializer
 
streamContexts_ - Variable in class org.apache.cassandra.dht.BootstrapInitiateMessage
 
StreamManager - Class in org.apache.cassandra.service
 
StreamManager.BootstrapTerminateVerbHandler - Class in org.apache.cassandra.service
 
StreamManager.BootstrapTerminateVerbHandler() - Constructor for class org.apache.cassandra.service.StreamManager.BootstrapTerminateVerbHandler
 
streamNotificationHandlers_ - Static variable in class org.apache.cassandra.net.io.StreamContextManager
 
streamStatus_ - Variable in class org.apache.cassandra.net.io.StreamContextManager.StreamStatusMessage
 
streamStatusBag_ - Static variable in class org.apache.cassandra.net.io.StreamContextManager
 
stringifyFileSize(double) - Static method in class org.apache.cassandra.utils.FileUtils
 
stringToFileSize(String) - Static method in class org.apache.cassandra.utils.FileUtils
 
StringToken - Class in org.apache.cassandra.dht
 
StringToken(String) - Constructor for class org.apache.cassandra.dht.StringToken
 
strip(String, String) - Static method in class org.apache.cassandra.utils.FBUtilities
 
subcolumnComparator - Variable in class org.apache.cassandra.config.CFMetaData
 
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(ColumnFamilyStore) - Method in class org.apache.cassandra.db.HintedHandOffManager
 
sum() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
sumOfDeviations() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
SuperColumn - Class in org.apache.cassandra.db
 
superColumnName - Variable in class org.apache.cassandra.db.filter.QueryPath
 
suspect(EndPoint) - Method in class org.apache.cassandra.gms.Gossiper
This method is part of IFailureDetectionEventListener interface.
suspect(EndPoint) - Method in interface org.apache.cassandra.gms.IFailureDetectionEventListener
Suspect the specified endpoint.
suspect(EndPoint) - Method in interface org.apache.cassandra.gms.IFailureNotification
 
sync() - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
SYSTEM_TABLE - Static variable in class org.apache.cassandra.db.Table
 
SystemTable - Class in org.apache.cassandra.db
 
SystemTable() - Constructor for class org.apache.cassandra.db.SystemTable
 
SystemTable.StorageMetadata - Class in org.apache.cassandra.db
 

T

table - Variable in class org.apache.cassandra.db.RangeCommand
 
table - Variable in class org.apache.cassandra.db.ReadCommand
 
table() - Method in class org.apache.cassandra.db.RowMutation
 
Table - Class in org.apache.cassandra.db
 
table() - Method in class org.apache.cassandra.db.WriteResponse
 
Table.BootstrapCompletionHandler - Class in org.apache.cassandra.db
This is the callback handler that is invoked when we have completely been bootstrapped for a single file by a remote host.
Table.BootstrapCompletionHandler() - Constructor for class org.apache.cassandra.db.Table.BootstrapCompletionHandler
 
Table.BootStrapInitiateVerbHandler - Class in org.apache.cassandra.db
 
Table.BootStrapInitiateVerbHandler() - Constructor for class org.apache.cassandra.db.Table.BootStrapInitiateVerbHandler
 
Table.TableMetadata - Class in org.apache.cassandra.db
 
Table.TableMetadata() - Constructor for class org.apache.cassandra.db.Table.TableMetadata
 
tableName - Variable in class org.apache.cassandra.config.CFMetaData
 
tableStats(String, DecimalFormat) - Method in class org.apache.cassandra.db.Table
 
takeAllSnapshot(String) - Method in class org.apache.cassandra.service.StorageService
Takes a snapshot for every table.
takeAllSnapshot(String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes a snapshot for every table.
takeSnapshot(String, String) - Method in class org.apache.cassandra.service.StorageService
Takes the snapshot for a given table.
takeSnapshot(String, String) - Method in interface org.apache.cassandra.service.StorageServiceMBean
Takes the snapshot for a given table.
takeSnapshot(String) - Method in class org.apache.cassandra.tools.NodeProbe
Take a snapshot of all the tables.
targets_ - Variable in class org.apache.cassandra.dht.BootStrapper
 
targets_ - Variable in class org.apache.cassandra.dht.LeaveJoinProtocolImpl
 
TASK_ID - Static variable in class org.apache.cassandra.net.HeaderTypes
 
TASK_PROFILE_CHAIN - Static variable in class org.apache.cassandra.net.HeaderTypes
 
TcpConnection - Class in org.apache.cassandra.net
 
TcpConnectionHandler - Class in org.apache.cassandra.net
 
TcpConnectionHandler(EndPoint) - Constructor for class org.apache.cassandra.net.TcpConnectionHandler
 
TcpReader - Class in org.apache.cassandra.net.io
 
TcpReader(TcpConnection) - Constructor for class org.apache.cassandra.net.io.TcpReader
 
TcpReader.TcpReaderState - Enum in org.apache.cassandra.net.io
 
tempDisableAutoCompaction() - Method in class org.apache.cassandra.utils.FastHash
Temporarily disables auto-compaction.
TEMPFILE_MARKER - Static variable in class org.apache.cassandra.io.SSTable
 
ThreadFactoryImpl - Class in org.apache.cassandra.concurrent
This class is an implementation of the ThreadFactory interface.
ThreadFactoryImpl(String) - Constructor for class org.apache.cassandra.concurrent.ThreadFactoryImpl
 
threadGroup_ - Variable in class org.apache.cassandra.concurrent.ThreadFactoryImpl
 
ThreadListBuilder - Class in org.apache.cassandra.tools
 
ThreadListBuilder() - Constructor for class org.apache.cassandra.tools.ThreadListBuilder
 
ThreadLocalContext - Class in org.apache.cassandra.concurrent
Use this implementation over Java's ThreadLocal or InheritableThreadLocal when you need to add multiple key/value pairs into ThreadLocalContext for a given thread.
ThreadLocalContext() - Constructor for class org.apache.cassandra.concurrent.ThreadLocalContext
 
threadNbr_ - Variable in class org.apache.cassandra.concurrent.ThreadFactoryImpl
 
thriftifyColumns(Collection<IColumn>, boolean) - Method in class org.apache.cassandra.service.CassandraServer
 
thriftifySubColumns(Collection<IColumn>) - Method in class org.apache.cassandra.service.CassandraServer
 
thriftPort - Variable in class org.apache.cassandra.cli.CliSessionState
 
ThriftValidation - Class in org.apache.cassandra.service
 
ThriftValidation() - Constructor for class org.apache.cassandra.service.ThriftValidation
 
throwableToString(Throwable) - Static method in class org.apache.cassandra.utils.LogUtil
 
throwObjectContractViolation(Object, Object) - Method in class org.apache.cassandra.utils.FastObjectHash
Convenience methods for subclasses to use in throwing exceptions about badly behaved user objects employed as keys.
TimedStatsDeque - Class in org.apache.cassandra.utils
threadsafe.
TimedStatsDeque(long) - Constructor for class org.apache.cassandra.utils.TimedStatsDeque
 
timestamp() - Method in class org.apache.cassandra.db.Column
 
timestamp(byte[]) - Method in class org.apache.cassandra.db.Column
 
timestamp() - Method in interface org.apache.cassandra.db.IColumn
 
timestamp(byte[]) - Method in interface org.apache.cassandra.db.IColumn
 
timestamp() - Method in class org.apache.cassandra.db.SuperColumn
 
timestamp(byte[]) - Method in class org.apache.cassandra.db.SuperColumn
 
TimeUUIDType - Class in org.apache.cassandra.db.marshal
 
TimeUUIDType() - Constructor for class org.apache.cassandra.db.marshal.TimeUUIDType
 
timingOn - Variable in class org.apache.cassandra.cli.CliSessionState
 
toByteArray(Token<T>) - Method in class org.apache.cassandra.dht.Token.TokenFactory
 
toByteArray(int) - Static method in class org.apache.cassandra.net.MessagingService
 
toByteArray(short) - Static method in class org.apache.cassandra.net.MessagingService
 
toByteArray(int) - Static method in class org.apache.cassandra.utils.FBUtilities
 
toBytes(EndPoint) - Static method in class org.apache.cassandra.net.EndPoint
 
Token<T> - Class in org.apache.cassandra.dht
 
Token(T) - Constructor for class org.apache.cassandra.dht.Token
 
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
 
TOKEN_MAP - Static variable in class org.apache.cassandra.service.CassandraServer
 
TokenMetadata - Class in org.apache.cassandra.locator
 
TokenMetadata() - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
TokenMetadata(Map<Token, EndPoint>, Map<EndPoint, Token>, Map<Token, EndPoint>) - Constructor for class org.apache.cassandra.locator.TokenMetadata
 
tokenMetadata_ - Variable in class org.apache.cassandra.dht.BootStrapper
 
tokenMetadata_ - Variable in class org.apache.cassandra.dht.LeaveJoinProtocolImpl
 
tokenMetadata_ - Variable in class org.apache.cassandra.locator.AbstractReplicationStrategy
 
tokens_ - Variable in class org.apache.cassandra.dht.BootStrapper
 
tokens_ - Variable in class org.apache.cassandra.dht.LeaveJoinProtocolImpl
 
TokenUpdater - Class in org.apache.cassandra.tools
 
TokenUpdater() - Constructor for class org.apache.cassandra.tools.TokenUpdater
 
TokenUpdateVerbHandler - Class in org.apache.cassandra.service
 
TokenUpdateVerbHandler() - Constructor for class org.apache.cassandra.service.TokenUpdateVerbHandler
 
TokenUpdateVerbHandler - Class in org.apache.cassandra.tools
 
TokenUpdateVerbHandler() - Constructor for class org.apache.cassandra.tools.TokenUpdateVerbHandler
 
tokenVerbHandler_ - Static variable in class org.apache.cassandra.service.StorageService
 
toString() - Method in class org.apache.cassandra.db.ColumnFamily
 
toString() - Method in class org.apache.cassandra.db.CommitLog.CommitLogContext
 
toString() - Method in class org.apache.cassandra.db.filter.QueryPath
 
toString() - Method in class org.apache.cassandra.db.Memtable
 
toString() - Method in class org.apache.cassandra.db.RangeCommand
 
toString() - Method in class org.apache.cassandra.db.RangeReply
 
toString() - Method in class org.apache.cassandra.db.Row
 
toString() - 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.TableMetadata
 
toString() - Method in class org.apache.cassandra.dht.BytesToken
 
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.locator.TokenMetadata
 
toString() - Method in class org.apache.cassandra.net.ConnectionStatistics
 
toString() - Method in class org.apache.cassandra.net.EndPoint
 
toString() - Method in class org.apache.cassandra.net.io.StreamContextManager.StreamContext
 
toString() - Method in class org.apache.cassandra.net.Message
 
toString() - Method in class org.apache.cassandra.net.TcpConnection
 
toString() - Method in class org.apache.cassandra.utils.BloomFilter
 
trimToSize() - Method in class org.apache.cassandra.utils.FastHash
This simply calls compact.
turnOffInterestOps(SelectionKey, int) - Static method in class org.apache.cassandra.net.SelectionKeyHandler
 
turnOnInterestOps(SelectionKey, int) - Static method in class org.apache.cassandra.net.SelectionKeyHandler
 
TWO - Static variable in class org.apache.cassandra.dht.RandomPartitioner
 
type() - Method in class org.apache.cassandra.db.ColumnFamily
 

U

UdpConnection - Class in org.apache.cassandra.net
 
UdpConnection() - Constructor for class org.apache.cassandra.net.UdpConnection
 
undecorateKey(String) - Method in class org.apache.cassandra.dht.CollatingOrderPreservingPartitioner
 
undecorateKey(String) - Method in interface org.apache.cassandra.dht.IPartitioner
 
undecorateKey(String) - Method in class org.apache.cassandra.dht.OrderPreservingPartitioner
 
undecorateKey(String) - Method in class org.apache.cassandra.dht.RandomPartitioner
 
unescapeSQLString(String) - Static method in class org.apache.cassandra.cli.CliUtils
 
unprotectedDigest() - Method in class org.apache.cassandra.utils.SafeMessageDigest
 
unprotectedDigest(byte[]) - Method in class org.apache.cassandra.utils.SafeMessageDigest
 
unprotectedUpdate(byte[]) - Method in class org.apache.cassandra.utils.SafeMessageDigest
 
unregister(IEndPointStateChangeSubscriber) - Method in class org.apache.cassandra.gms.Gossiper
 
unregister(IEndPointStateChangeSubscriber) - Method in interface org.apache.cassandra.gms.IEndPointStateChangePublisher
Unregister interest for state changes.
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.
update(Token, EndPoint) - Method in class org.apache.cassandra.locator.TokenMetadata
 
update(Token, EndPoint, boolean) - Method in class org.apache.cassandra.locator.TokenMetadata
Update the two maps in an safe mode.
update(byte[]) - Method in class org.apache.cassandra.utils.SafeMessageDigest
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.Column
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.ColumnFamily
 
updateDigest(MessageDigest) - Method in interface org.apache.cassandra.db.IColumn
 
updateDigest(MessageDigest) - Method in class org.apache.cassandra.db.SuperColumn
 
updateToken(Token) - Static method in class org.apache.cassandra.db.SystemTable
 
updateToken(Token) - Method in class org.apache.cassandra.service.StorageService
 
updateTokenMetadata(Token, EndPoint, boolean) - Method in class org.apache.cassandra.service.StorageService
 
UTF8Type - Class in org.apache.cassandra.db.marshal
 
UTF8Type() - Constructor for class org.apache.cassandra.db.marshal.UTF8Type
 
utfPrefix_ - Static variable in class org.apache.cassandra.db.ColumnFamily
 
UtfPrefix_ - Static variable in interface org.apache.cassandra.db.IColumn
 

V

validate(byte[]) - Method in class org.apache.cassandra.db.marshal.AbstractType
validate that the byte array is a valid sequence for the type we are supposed to be comparing
validateColumnFamily(String, String) - Static method in class org.apache.cassandra.service.ThriftValidation
 
validateColumns(String, ColumnParent, Iterable<byte[]>) - Static method in class org.apache.cassandra.service.ThriftValidation
 
validateRange(String, ColumnParent, SliceRange) - Static method in class org.apache.cassandra.service.ThriftValidation
 
value() - Method in class org.apache.cassandra.db.Column
 
value(byte[]) - Method in class org.apache.cassandra.db.Column
 
value() - Method in interface org.apache.cassandra.db.IColumn
 
value(byte[]) - Method in interface org.apache.cassandra.db.IColumn
 
value() - Method in class org.apache.cassandra.db.SuperColumn
 
value(byte[]) - Method in class org.apache.cassandra.db.SuperColumn
 
valueOf(String) - Static method in enum org.apache.cassandra.config.DatabaseDescriptor.CommitLogSync
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.net.io.StreamContextManager.StreamCompletionAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum org.apache.cassandra.net.io.TcpReader.TcpReaderState
Returns the enum constant of this type with the specified name.
values() - Static method in enum org.apache.cassandra.config.DatabaseDescriptor.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.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.net.io.StreamContextManager.StreamCompletionAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum org.apache.cassandra.net.io.TcpReader.TcpReaderState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class org.apache.cassandra.utils.FastHashMap
Returns a view on the values of the map.
values_ - Variable in class org.apache.cassandra.utils.FastHashMap
the values of the map
variance() - Method in class org.apache.cassandra.utils.AbstractStatsDeque
 
VERSION - Static variable in class org.apache.cassandra.net.ProtocolHeader
 
version_ - Variable in class org.apache.cassandra.net.ProtocolHeader
 
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

waitForStreamCompletion() - Method in class org.apache.cassandra.service.StreamManager
 
warn(Object) - Method in class org.apache.cassandra.utils.Log4jLogger
 
width - Variable in class org.apache.cassandra.io.IndexHelper.IndexInfo
 
write(int) - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
write(byte[]) - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
write(byte[], int, int) - Method in class org.apache.cassandra.io.BufferedRandomAccessFile
 
write(DataInput, int) - Method in class org.apache.cassandra.io.DataOutputBuffer
Writes bytes from a DataInput directly into the buffer.
write(int) - Method in class org.apache.cassandra.io.FastBufferedOutputStream
Writes the specified byte to this buffered output stream.
write(byte[], int, int) - Method in class org.apache.cassandra.io.FastBufferedOutputStream
Writes len bytes from the specified byte array starting at offset off to this buffered output stream.
write(SelectionKey) - Method in class org.apache.cassandra.net.SelectionKeyHandler
Method which is called when the key becomes writable.
write(Message) - Method in class org.apache.cassandra.net.TcpConnection
 
write(SelectionKey) - Method in class org.apache.cassandra.net.TcpConnection
 
write(Message, EndPoint) - Method in class org.apache.cassandra.net.UdpConnection
 
writeByteArray(byte[], DataOutput) - Static method in class org.apache.cassandra.utils.FBUtilities
 
writeName(byte[], DataOutput) - Static method in class org.apache.cassandra.db.ColumnSerializer
 
WriteResponse - Class in org.apache.cassandra.db
 
WriteResponse(String, String, 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
 
WriteResponseResolver - Class in org.apache.cassandra.service
 
WriteResponseResolver() - Constructor for class org.apache.cassandra.service.WriteResponseResolver
 

X

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
 

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

Copyright © 2009 The Apache Software Foundation